Spark 4.0.0 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

Visibility

  1. Public
  2. Protected

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)

Type Members

  1. implicit class LogStringContext extends AnyRef

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: AnyRef): 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. final def getClass(): Class[_ <: AnyRef]
  17. def getState(): StreamingContextState
  18. def hashCode(): Int
  19. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
  20. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
  21. final def isInstanceOf[T0]: Boolean
  22. def isTraceEnabled(): Boolean
  23. def log: Logger
  24. def logDebug(msg: => String, throwable: Throwable): Unit
  25. def logDebug(entry: LogEntry, throwable: Throwable): Unit
  26. def logDebug(entry: LogEntry): Unit
  27. def logDebug(msg: => String): Unit
  28. def logError(msg: => String, throwable: Throwable): Unit
  29. def logError(entry: LogEntry, throwable: Throwable): Unit
  30. def logError(entry: LogEntry): Unit
  31. def logError(msg: => String): Unit
  32. def logInfo(msg: => String, throwable: Throwable): Unit
  33. def logInfo(entry: LogEntry, throwable: Throwable): Unit
  34. def logInfo(entry: LogEntry): Unit
  35. def logInfo(msg: => String): Unit
  36. def logName: String
  37. def logTrace(msg: => String, throwable: Throwable): Unit
  38. def logTrace(entry: LogEntry, throwable: Throwable): Unit
  39. def logTrace(entry: LogEntry): Unit
  40. def logTrace(msg: => String): Unit
  41. def logWarning(msg: => String, throwable: Throwable): Unit
  42. def logWarning(entry: LogEntry, throwable: Throwable): Unit
  43. def logWarning(entry: LogEntry): Unit
  44. def logWarning(msg: => String): Unit
  45. final def ne(arg0: AnyRef): Boolean
  46. final def notify(): Unit
  47. final def notifyAll(): Unit
  48. def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean, defaultRDD: RDD[T])(implicit arg0: ClassTag[T]): InputDStream[T]
  49. def queueStream[T](queue: Queue[RDD[T]], oneAtATime: Boolean = true)(implicit arg0: ClassTag[T]): InputDStream[T]
  50. def rawSocketStream[T](hostname: String, port: Int, storageLevel: StorageLevel = StorageLevel.MEMORY_AND_DISK_SER_2)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
  51. def receiverStream[T](receiver: Receiver[T])(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
  52. def remember(duration: Duration): Unit
  53. def removeStreamingListener(streamingListener: StreamingListener): Unit
  54. def socketStream[T](hostname: String, port: Int, converter: (InputStream) => Iterator[T], storageLevel: StorageLevel)(implicit arg0: ClassTag[T]): ReceiverInputDStream[T]
  55. def socketTextStream(hostname: String, port: Int, storageLevel: StorageLevel = StorageLevel.MEMORY_AND_DISK_SER_2): ReceiverInputDStream[String]
  56. def sparkContext: SparkContext
  57. def start(): Unit
  58. def stop(stopSparkContext: Boolean, stopGracefully: Boolean): Unit
  59. def stop(stopSparkContext: Boolean = conf.getBoolean("spark.streaming.stopSparkContextByDefault", true)): Unit
  60. final def synchronized[T0](arg0: => T0): T0
  61. def textFileStream(directory: String): DStream[String]
  62. def toString(): String
  63. def transform[T](dstreams: Seq[DStream[_]], transformFunc: (Seq[RDD[_]], Time) => RDD[T])(implicit arg0: ClassTag[T]): DStream[T]
  64. def union[T](streams: Seq[DStream[T]])(implicit arg0: ClassTag[T]): DStream[T]
  65. final def wait(arg0: Long, arg1: Int): Unit
  66. final def wait(arg0: Long): Unit
  67. final def wait(): Unit
  68. def withLogContext(context: Map[String, String])(body: => Unit): Unit

Deprecated Value Members

  1. def finalize(): Unit

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped