Spark 3.5.5 ScalaDoc - org.apache.spark.streaming.dstream.DStream (original) (raw)
abstract class DStream[T] extends Serializable with Logging
Ordering
- Alphabetic
- By Inheritance
Inherited
DStream
Logging
Serializable
Serializable
AnyRef
Any
Hide All
Show All
Instance Constructors
- new DStream(ssc: StreamingContext)(implicit arg0: ClassTag[T])
Abstract Value Members
- abstract def compute(validTime: Time): Option[RDD[T]]
- abstract def dependencies: List[DStream[_]]
- abstract def slideDuration: Duration
Concrete Value Members
- final def !=(arg0: Any): Boolean
- final def ##(): Int
- final def ==(arg0: Any): Boolean
- final def asInstanceOf[T0]: T0
- val baseScope: Option[String]
- def cache(): DStream[T]
- def checkpoint(interval: Duration): DStream[T]
- def clone(): AnyRef
- def context: StreamingContext
- def count(): DStream[Long]
- def countByValue(numPartitions: Int = ssc.sc.defaultParallelism)(implicit ord: Ordering[T] = null): DStream[(T, Long)]
- def countByValueAndWindow(windowDuration: Duration, slideDuration: Duration, numPartitions: Int = ssc.sc.defaultParallelism)(implicit ord: Ordering[T] = null): DStream[(T, Long)]
- def countByWindow(windowDuration: Duration, slideDuration: Duration): DStream[Long]
- def createRDDWithLocalProperties[U](time: Time, displayInnerRDDOps: Boolean)(body: ⇒ U): U
- final def eq(arg0: AnyRef): Boolean
- def equals(arg0: Any): Boolean
- def filter(filterFunc: (T) ⇒ Boolean): DStream[T]
- def finalize(): Unit
- def flatMap[U](flatMapFunc: (T) ⇒ TraversableOnce[U])(implicit arg0: ClassTag[U]): DStream[U]
- def foreachRDD(foreachFunc: (RDD[T], Time) ⇒ Unit): Unit
- def foreachRDD(foreachFunc: (RDD[T]) ⇒ Unit): Unit
- final def getClass(): Class[_]
- def glom(): DStream[Array[T]]
- 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(msg: ⇒ String): Unit
- def logError(msg: ⇒ String, throwable: Throwable): Unit
- def logError(msg: ⇒ String): Unit
- def logInfo(msg: ⇒ String, throwable: Throwable): Unit
- def logInfo(msg: ⇒ String): Unit
- def logName: String
- def logTrace(msg: ⇒ String, throwable: Throwable): Unit
- def logTrace(msg: ⇒ String): Unit
- def logWarning(msg: ⇒ String, throwable: Throwable): Unit
- def logWarning(msg: ⇒ String): Unit
- def map[U](mapFunc: (T) ⇒ U)(implicit arg0: ClassTag[U]): DStream[U]
- def mapPartitions[U](mapPartFunc: (Iterator[T]) ⇒ Iterator[U], preservePartitioning: Boolean = false)(implicit arg0: ClassTag[U]): DStream[U]
- final def ne(arg0: AnyRef): Boolean
- final def notify(): Unit
- final def notifyAll(): Unit
- def persist(): DStream[T]
- def persist(level: StorageLevel): DStream[T]
- def print(num: Int): Unit
- def print(): Unit
- def reduce(reduceFunc: (T, T) ⇒ T): DStream[T]
- def reduceByWindow(reduceFunc: (T, T) ⇒ T, invReduceFunc: (T, T) ⇒ T, windowDuration: Duration, slideDuration: Duration): DStream[T]
- def reduceByWindow(reduceFunc: (T, T) ⇒ T, windowDuration: Duration, slideDuration: Duration): DStream[T]
- def repartition(numPartitions: Int): DStream[T]
- def saveAsObjectFiles(prefix: String, suffix: String = ""): Unit
- def saveAsTextFiles(prefix: String, suffix: String = ""): Unit
- def slice(fromTime: Time, toTime: Time): Seq[RDD[T]]
- def slice(interval: Interval): Seq[RDD[T]]
- final def synchronized[T0](arg0: ⇒ T0): T0
- def toString(): String
- def transform[U](transformFunc: (RDD[T], Time) ⇒ RDD[U])(implicit arg0: ClassTag[U]): DStream[U]
- def transform[U](transformFunc: (RDD[T]) ⇒ RDD[U])(implicit arg0: ClassTag[U]): DStream[U]
- def transformWith[U, V](other: DStream[U], transformFunc: (RDD[T], RDD[U], Time) ⇒ RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]
- def transformWith[U, V](other: DStream[U], transformFunc: (RDD[T], RDD[U]) ⇒ RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]
- def union(that: DStream[T]): DStream[T]
- final def wait(): Unit
- final def wait(arg0: Long, arg1: Int): Unit
- final def wait(arg0: Long): Unit
- def window(windowDuration: Duration, slideDuration: Duration): DStream[T]
- def window(windowDuration: Duration): DStream[T]