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

abstract class ReceiverInputDStream[T] extends InputDStream[T]

Ordering

  1. Alphabetic
  2. By Inheritance

Inherited

  1. ReceiverInputDStream

  2. InputDStream

  3. DStream

  4. Logging

  5. Serializable

  6. Serializable

  7. AnyRef

  8. Any

  9. Hide All

  10. Show All

Instance Constructors

  1. new ReceiverInputDStream(_ssc: StreamingContext)(implicit arg0: ClassTag[T])

Abstract Value Members

  1. abstract def getReceiver(): Receiver[T]

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

Inherited from InputDStream[T]

Inherited from DStream[T]

Inherited from Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped