Spark 4.0.0 ScalaDoc - org.apache.spark.streaming.StreamingContext (original) (raw)
class StreamingContext extends Logging
Ordering
- Alphabetic
- By Inheritance
Inherited
StreamingContext
Logging
AnyRef
Any
Hide All
Show All
Visibility
- Public
- Protected
Instance Constructors
- new StreamingContext(path: String, sparkContext: SparkContext)
- new StreamingContext(path: String)
- new StreamingContext(path: String, hadoopConf: Configuration)
- new StreamingContext(master: String, appName: String, batchDuration: Duration, sparkHome: String = null, jars: Seq[String] = Nil, environment: Map[String, String] = Map())
- new StreamingContext(conf: SparkConf, batchDuration: Duration)
- new StreamingContext(sparkContext: SparkContext, batchDuration: Duration)
Type Members
- implicit class LogStringContext extends AnyRef
Value Members
- final def !=(arg0: Any): Boolean
- final def ##: Int
- final def ==(arg0: Any): Boolean
- def addStreamingListener(streamingListener: StreamingListener): Unit
- final def asInstanceOf[T0]: T0
- def awaitTermination(): Unit
- def awaitTerminationOrTimeout(timeout: Long): Boolean
- def binaryRecordsStream(directory: String, recordLength: Int): DStream[Array[Byte]]
- def checkpoint(directory: String): Unit
- def clone(): AnyRef
- final def eq(arg0: AnyRef): Boolean
- def equals(arg0: AnyRef): Boolean
- def fileStream[K, V, F <: InputFormat[K, V]](directory: String, filter: (Path) => Boolean, newFilesOnly: Boolean, conf: Configuration)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]
- def fileStream[K, V, F <: InputFormat[K, V]](directory: String, filter: (Path) => Boolean, newFilesOnly: Boolean)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]
- def fileStream[K, V, F <: InputFormat[K, V]](directory: String)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]
- final def getClass(): Class[_ <: AnyRef]
- def getState(): StreamingContextState
- def hashCode(): Int
- def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
- def initializeLogIfNecessary(isInterpreter: Boolean): Unit
- final def isInstanceOf[T0]: Boolean
- def isTraceEnabled(): Boolean
- def log: Logger
- def logDebug(msg: => String, throwable: Throwable): Unit
- def logDebug(entry: LogEntry, throwable: Throwable): Unit
- def logDebug(entry: LogEntry): Unit
- def logDebug(msg: => String): Unit
- def logError(msg: => String, throwable: Throwable): Unit
- def logError(entry: LogEntry, throwable: Throwable): Unit
- def logError(entry: LogEntry): Unit
- def logError(msg: => String): Unit
- def logInfo(msg: => String, throwable: Throwable): Unit
- def logInfo(entry: LogEntry, throwable: Throwable): Unit
- def logInfo(entry: LogEntry): Unit
- def logInfo(msg: => String): Unit
- def logName: String
- def logTrace(msg: => String, throwable: Throwable): Unit
- def logTrace(entry: LogEntry, throwable: Throwable): Unit
- def logTrace(entry: LogEntry): Unit
- def logTrace(msg: => String): Unit
- def logWarning(msg: => String, throwable: Throwable): Unit
- def logWarning(entry: LogEntry, throwable: Throwable): Unit
- def logWarning(entry: LogEntry): Unit
- def logWarning(msg: => String): Unit
- final def ne(arg0: AnyRef): Boolean
- final def notify(): Unit
- final def notifyAll(): Unit
- def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean, defaultRDD: RDD[T])(implicit arg0: ClassTag[T]): InputDStream[T]
- def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean = true)(implicit arg0: ClassTag[T]): InputDStream[T]
- def rawSocketStream[T](hostname: String, port: Int, storageLevel: StorageLevel = StorageLevel.MEMORY_AND_DISK_SER_2)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
- def receiverStream[T](receiver: Receiver[T])(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
- def remember(duration: Duration): Unit
- def removeStreamingListener(streamingListener: StreamingListener): Unit
- def socketStream[T](hostname: String, port: Int, converter: (InputStream) => Iterator[T], storageLevel: StorageLevel)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
- def socketTextStream(hostname: String, port: Int, storageLevel: StorageLevel = StorageLevel.MEMORY_AND_DISK_SER_2): ReceiverInputDStream[String]
- def sparkContext: SparkContext
- def start(): Unit
- def stop(stopSparkContext: Boolean, stopGracefully: Boolean): Unit
- def stop(stopSparkContext: Boolean = conf.getBoolean("spark.streaming.stopSparkContextByDefault", true)): Unit
- final def synchronized[T0](arg0: => T0): T0
- def textFileStream(directory: String): DStream[String]
- def toString(): String
- def transform[T](dstreams: Seq[DStream[_]], transformFunc: (Seq[RDD[_]], Time) => RDD[T])(implicit arg0: ClassTag[T]): DStream[T]
- def union[T](streams: Seq[DStream[T]])(implicit arg0: ClassTag[T]): DStream[T]
- final def wait(arg0: Long, arg1: Int): Unit
- final def wait(arg0: Long): Unit
- final def wait(): Unit
- def withLogContext(context: Map[String, String])(body: => Unit): Unit
Deprecated Value Members
- def finalize(): Unit