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

  7. Any

  8. Hide All

  9. Show All

Visibility

  1. Public
  2. Protected

Instance Constructors

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

Type Members

  1. implicit class LogStringContext extends AnyRef

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

Deprecated Value Members

  1. def finalize(): Unit

Ungrouped