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

abstract class DStream[T] extends Serializable with Logging

Ordering

  1. Alphabetic
  2. By Inheritance

Inherited

  1. DStream

  2. Logging

  3. Serializable

  4. Serializable

  5. AnyRef

  6. Any

  7. Hide All

  8. Show All

Instance Constructors

  1. new DStream(ssc: StreamingContext)(implicit arg0: ClassTag[T])

Abstract Value Members

  1. abstract def compute(validTime: Time): Option[RDD[T]]
  2. abstract def dependencies: List[DStream[_]]
  3. abstract def slideDuration: Duration

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
  2. final def ##(): Int
  3. final def ==(arg0: Any): Boolean
  4. final def asInstanceOf[T0]: T0
  5. val baseScope: Option[String]
  6. def cache(): DStream[T]
  7. def checkpoint(interval: Duration): DStream[T]
  8. def clone(): AnyRef
  9. def context: StreamingContext
  10. def count(): DStream[Long]
  11. def countByValue(numPartitions: Int = ssc.sc.defaultParallelism)(implicit ord: Ordering[T] = null): DStream[(T, Long)]
  12. def countByValueAndWindow(windowDuration: Duration, slideDuration: Duration, numPartitions: Int = ssc.sc.defaultParallelism)(implicit ord: Ordering[T] = null): DStream[(T, Long)]
  13. def countByWindow(windowDuration: Duration, slideDuration: Duration): DStream[Long]
  14. def createRDDWithLocalProperties[U](time: Time, displayInnerRDDOps: Boolean)(body: ⇒ U): U
  15. final def eq(arg0: AnyRef): Boolean
  16. def equals(arg0: Any): Boolean
  17. def filter(filterFunc: (T) ⇒ Boolean): DStream[T]
  18. def finalize(): Unit
  19. def flatMap[U](flatMapFunc: (T) ⇒ TraversableOnce[U])(implicit arg0: ClassTag[U]): DStream[U]
  20. def foreachRDD(foreachFunc: (RDD[T], Time) ⇒ Unit): Unit
  21. def foreachRDD(foreachFunc: (RDD[T]) ⇒ Unit): Unit
  22. final def getClass(): Class[_]
  23. def glom(): DStream[Array[T]]
  24. def hashCode(): Int
  25. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
  26. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
  27. final def isInstanceOf[T0]: Boolean
  28. def isTraceEnabled(): Boolean
  29. def log: Logger
  30. def logDebug(msg: ⇒ String, throwable: Throwable): Unit
  31. def logDebug(msg: ⇒ String): Unit
  32. def logError(msg: ⇒ String, throwable: Throwable): Unit
  33. def logError(msg: ⇒ String): Unit
  34. def logInfo(msg: ⇒ String, throwable: Throwable): Unit
  35. def logInfo(msg: ⇒ String): Unit
  36. def logName: String
  37. def logTrace(msg: ⇒ String, throwable: Throwable): Unit
  38. def logTrace(msg: ⇒ String): Unit
  39. def logWarning(msg: ⇒ String, throwable: Throwable): Unit
  40. def logWarning(msg: ⇒ String): Unit
  41. def map[U](mapFunc: (T) ⇒ U)(implicit arg0: ClassTag[U]): DStream[U]
  42. def mapPartitions[U](mapPartFunc: (Iterator[T]) ⇒ Iterator[U], preservePartitioning: Boolean = false)(implicit arg0: ClassTag[U]): DStream[U]
  43. final def ne(arg0: AnyRef): Boolean
  44. final def notify(): Unit
  45. final def notifyAll(): Unit
  46. def persist(): DStream[T]
  47. def persist(level: StorageLevel): DStream[T]
  48. def print(num: Int): Unit
  49. def print(): Unit
  50. def reduce(reduceFunc: (T, T) ⇒ T): DStream[T]
  51. def reduceByWindow(reduceFunc: (T, T) ⇒ T, invReduceFunc: (T, T) ⇒ T, windowDuration: Duration, slideDuration: Duration): DStream[T]
  52. def reduceByWindow(reduceFunc: (T, T) ⇒ T, windowDuration: Duration, slideDuration: Duration): DStream[T]
  53. def repartition(numPartitions: Int): DStream[T]
  54. def saveAsObjectFiles(prefix: String, suffix: String = ""): Unit
  55. def saveAsTextFiles(prefix: String, suffix: String = ""): Unit
  56. def slice(fromTime: Time, toTime: Time): Seq[RDD[T]]
  57. def slice(interval: Interval): Seq[RDD[T]]
  58. final def synchronized[T0](arg0: ⇒ T0): T0
  59. def toString(): String
  60. def transform[U](transformFunc: (RDD[T], Time) ⇒ RDD[U])(implicit arg0: ClassTag[U]): DStream[U]
  61. def transform[U](transformFunc: (RDD[T]) ⇒ RDD[U])(implicit arg0: ClassTag[U]): DStream[U]
  62. def transformWith[U, V](other: DStream[U], transformFunc: (RDD[T], RDD[U], Time) ⇒ RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]
  63. def transformWith[U, V](other: DStream[U], transformFunc: (RDD[T], RDD[U]) ⇒ RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]
  64. def union(that: DStream[T]): DStream[T]
  65. final def wait(): Unit
  66. final def wait(arg0: Long, arg1: Int): Unit
  67. final def wait(arg0: Long): Unit
  68. def window(windowDuration: Duration, slideDuration: Duration): DStream[T]
  69. def window(windowDuration: Duration): DStream[T]

Inherited from Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped