| Class | Description |
|---|---|
| ConstantInputDStream<T> |
An input stream that always returns the same RDD on each timestep.
|
| DStream<T> |
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.apache.spark.rdd.RDD in the Spark core documentation for more details on RDDs).
|
| DStreamCheckpointData<T> | |
| FileInputDStream<K,V,F extends org.apache.hadoop.mapreduce.InputFormat<K,V>> |
This class represents an input stream that monitors a Hadoop-compatible filesystem for new
files and creates a stream out of them.
|
| FilteredDStream<T> | |
| FlatMappedDStream<T,U> | |
| FlatMapValuedDStream<K,V,U> | |
| ForEachDStream<T> | |
| GlommedDStream<T> | |
| InputDStream<T> |
This is the abstract base class for all input streams.
|
| MapPartitionedDStream<T,U> | |
| MappedDStream<T,U> | |
| MapValuedDStream<K,V,U> | |
| PairDStreamFunctions<K,V> |
Extra functions available on DStream of (key, value) pairs through an implicit conversion.
|
| PluggableInputDStream<T> | |
| QueueInputDStream<T> | |
| RawInputDStream<T> |
An input stream that reads blocks of serialized objects from a given network address.
|
| RawNetworkReceiver | |
| ReceiverInputDStream<T> |
Abstract class for defining any
InputDStream
that has to start a receiver on worker nodes to receive external data. |
| ReducedWindowedDStream<K,V> | |
| ShuffledDStream<K,V,C> | |
| SocketInputDStream<T> | |
| SocketReceiver<T> | |
| StateDStream<K,V,S> | |
| TransformedDStream<U> | |
| UnionDStream<T> | |
| WindowedDStream<T> |