Spark 3.5.5 ScalaDoc - org.apache.spark.streaming.StreamingContext (original) (raw)

class StreamingContext extends Logging

Ordering

  1. Alphabetic
  2. By Inheritance

Inherited

  1. StreamingContext

  2. Logging

  3. AnyRef

  4. Any

  5. Hide All

  6. Show All

Instance Constructors

  1. new StreamingContext(path: String, sparkContext: SparkContext)
  2. new StreamingContext(path: String)
  3. new StreamingContext(path: String, hadoopConf: Configuration)
  4. new StreamingContext(master: String, appName: String, batchDuration: Duration, sparkHome: String = null, jars: Seq[String] = Nil, environment: Map[String, String] = Map())
  5. new StreamingContext(conf: SparkConf, batchDuration: Duration)
  6. new StreamingContext(sparkContext: SparkContext, batchDuration: Duration)

Value Members

  1. final def !=(arg0: Any): Boolean
  2. final def ##(): Int
  3. final def ==(arg0: Any): Boolean
  4. def addStreamingListener(streamingListener: StreamingListener): Unit
  5. final def asInstanceOf[T0]: T0
  6. def awaitTermination(): Unit
  7. def awaitTerminationOrTimeout(timeout: Long): Boolean
  8. def binaryRecordsStream(directory: String, recordLength: Int): DStream[Array[Byte]]
  9. def checkpoint(directory: String): Unit
  10. def clone(): AnyRef
  11. final def eq(arg0: AnyRef): Boolean
  12. def equals(arg0: Any): Boolean
  13. 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)]
  14. 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)]
  15. def fileStream[K, V, F <: InputFormat[K, V]](directory: String)(implicit arg0: ClassTag[K], arg1: ClassTag[V], arg2: ClassTag[F]): InputDStream[(K, V)]
  16. def finalize(): Unit
  17. final def getClass(): Class[_]
  18. def getState(): StreamingContextState
  19. def hashCode(): Int
  20. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
  21. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
  22. final def isInstanceOf[T0]: Boolean
  23. def isTraceEnabled(): Boolean
  24. def log: Logger
  25. def logDebug(msg: ⇒ String, throwable: Throwable): Unit
  26. def logDebug(msg: ⇒ String): Unit
  27. def logError(msg: ⇒ String, throwable: Throwable): Unit
  28. def logError(msg: ⇒ String): Unit
  29. def logInfo(msg: ⇒ String, throwable: Throwable): Unit
  30. def logInfo(msg: ⇒ String): Unit
  31. def logName: String
  32. def logTrace(msg: ⇒ String, throwable: Throwable): Unit
  33. def logTrace(msg: ⇒ String): Unit
  34. def logWarning(msg: ⇒ String, throwable: Throwable): Unit
  35. def logWarning(msg: ⇒ String): Unit
  36. final def ne(arg0: AnyRef): Boolean
  37. final def notify(): Unit
  38. final def notifyAll(): Unit
  39. def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean, defaultRDD: RDD[T])(implicit arg0: ClassTag[T]): InputDStream[T]
  40. def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean = true)(implicit arg0: ClassTag[T]): InputDStream[T]
  41. def rawSocketStream[T](hostname: String, port: Int, storageLevel: StorageLevel = StorageLevel.MEMORY_AND_DISK_SER_2)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
  42. def receiverStream[T](receiver: Receiver[T])(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
  43. def remember(duration: Duration): Unit
  44. def removeStreamingListener(streamingListener: StreamingListener): Unit
  45. def socketStream[T](hostname: String, port: Int, converter: (InputStream) ⇒ Iterator[T], storageLevel: StorageLevel)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
  46. def socketTextStream(hostname: String, port: Int, storageLevel: StorageLevel = StorageLevel.MEMORY_AND_DISK_SER_2): ReceiverInputDStream[String]
  47. def sparkContext: SparkContext
  48. def start(): Unit
  49. def stop(stopSparkContext: Boolean, stopGracefully: Boolean): Unit
  50. def stop(stopSparkContext: Boolean = ...): Unit
  51. final def synchronized[T0](arg0: ⇒ T0): T0
  52. def textFileStream(directory: String): DStream[String]
  53. def toString(): String
  54. def transform[T](dstreams: Seq[DStream[_]], transformFunc: (Seq[RDD[_]], Time) ⇒ RDD[T])(implicit arg0: ClassTag[T]): DStream[T]
  55. def union[T](streams: Seq[DStream[T]])(implicit arg0: ClassTag[T]): DStream[T]
  56. final def wait(): Unit
  57. final def wait(arg0: Long, arg1: Int): Unit
  58. final def wait(arg0: Long): Unit

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped