org.apache.spark.streaming

dstream

package dstream

Visibility
  1. Public
  2. All

Type Members

  1. class ConstantInputDStream[T] extends InputDStream[T]

    An input stream that always returns the same RDD on each timestep.

  2. abstract class DStream[T] extends Serializable with Logging

    A Discretized Stream (DStream), the basic abstraction in Spark Streaming, is a continuous sequence of RDDs (of the same type) representing a continuous stream of data (see org.

  3. abstract class InputDStream[T] extends DStream[T]

    This is the abstract base class for all input streams.

  4. abstract class NetworkInputDStream[T] extends InputDStream[T]

    Abstract class for defining any org.apache.spark.streaming.dstream.InputDStream that has to start a receiver on worker nodes to receive external data.

  5. abstract class NetworkReceiver[T] extends Serializable with Logging

    Abstract class of a receiver that can be run on worker nodes to receive external data.

  6. class PairDStreamFunctions[K, V] extends Serializable

    Extra functions available on DStream of (key, value) pairs through an implicit conversion.

Ungrouped