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

  5. Any

  6. Hide All

  7. Show All

Visibility

  1. Public
  2. Protected

Instance Constructors

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

Type Members

  1. implicit class LogStringContext extends AnyRef

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: AnyRef): Boolean
  17. def filter(filterFunc: (T) => Boolean): DStream[T]
  18. def flatMap[U](flatMapFunc: (T) => IterableOnce[U])(implicit arg0: ClassTag[U]): DStream[U]
  19. def foreachRDD(foreachFunc: (RDD[T], Time) => Unit): Unit
  20. def foreachRDD(foreachFunc: (RDD[T]) => Unit): Unit
  21. final def getClass(): Class[_ <: AnyRef]
  22. def glom(): DStream[Array[T]]
  23. def hashCode(): Int
  24. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
  25. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
  26. final def isInstanceOf[T0]: Boolean
  27. def isTraceEnabled(): Boolean
  28. def log: Logger
  29. def logDebug(msg: => String, throwable: Throwable): Unit
  30. def logDebug(entry: LogEntry, throwable: Throwable): Unit
  31. def logDebug(entry: LogEntry): Unit
  32. def logDebug(msg: => String): Unit
  33. def logError(msg: => String, throwable: Throwable): Unit
  34. def logError(entry: LogEntry, throwable: Throwable): Unit
  35. def logError(entry: LogEntry): Unit
  36. def logError(msg: => String): Unit
  37. def logInfo(msg: => String, throwable: Throwable): Unit
  38. def logInfo(entry: LogEntry, throwable: Throwable): Unit
  39. def logInfo(entry: LogEntry): Unit
  40. def logInfo(msg: => String): Unit
  41. def logName: String
  42. def logTrace(msg: => String, throwable: Throwable): Unit
  43. def logTrace(entry: LogEntry, throwable: Throwable): Unit
  44. def logTrace(entry: LogEntry): Unit
  45. def logTrace(msg: => String): Unit
  46. def logWarning(msg: => String, throwable: Throwable): Unit
  47. def logWarning(entry: LogEntry, throwable: Throwable): Unit
  48. def logWarning(entry: LogEntry): Unit
  49. def logWarning(msg: => String): Unit
  50. def map[U](mapFunc: (T) => U)(implicit arg0: ClassTag[U]): DStream[U]
  51. def mapPartitions[U](mapPartFunc: (Iterator[T]) => Iterator[U], preservePartitioning: Boolean = false)(implicit arg0: ClassTag[U]): DStream[U]
  52. final def ne(arg0: AnyRef): Boolean
  53. final def notify(): Unit
  54. final def notifyAll(): Unit
  55. def persist(): DStream[T]
  56. def persist(level: StorageLevel): DStream[T]
  57. def print(num: Int): Unit
  58. def print(): Unit
  59. def reduce(reduceFunc: (T, T) => T): DStream[T]
  60. def reduceByWindow(reduceFunc: (T, T) => T, invReduceFunc: (T, T) => T, windowDuration: Duration, slideDuration: Duration): DStream[T]
  61. def reduceByWindow(reduceFunc: (T, T) => T, windowDuration: Duration, slideDuration: Duration): DStream[T]
  62. def repartition(numPartitions: Int): DStream[T]
  63. def saveAsObjectFiles(prefix: String, suffix: String = ""): Unit
  64. def saveAsTextFiles(prefix: String, suffix: String = ""): Unit
  65. def slice(fromTime: Time, toTime: Time): Seq[RDD[T]]
  66. def slice(interval: Interval): Seq[RDD[T]]
  67. final def synchronized[T0](arg0: => T0): T0
  68. def toString(): String
  69. def transform[U](transformFunc: (RDD[T], Time) => RDD[U])(implicit arg0: ClassTag[U]): DStream[U]
  70. def transform[U](transformFunc: (RDD[T]) => RDD[U])(implicit arg0: ClassTag[U]): DStream[U]
  71. def transformWith[U, V](other: DStream[U], transformFunc: (RDD[T], RDD[U], Time) => RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]
  72. def transformWith[U, V](other: DStream[U], transformFunc: (RDD[T], RDD[U]) => RDD[V])(implicit arg0: ClassTag[U], arg1: ClassTag[V]): DStream[V]
  73. def union(that: DStream[T]): DStream[T]
  74. final def wait(arg0: Long, arg1: Int): Unit
  75. final def wait(arg0: Long): Unit
  76. final def wait(): Unit
  77. def window(windowDuration: Duration, slideDuration: Duration): DStream[T]
  78. def window(windowDuration: Duration): DStream[T]
  79. def withLogContext(context: Map[String, String])(body: => Unit): Unit

Deprecated Value Members

  1. def finalize(): Unit

Inherited from Logging

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped