:: Experimental ::
Abstract class for getting and updating the state in mapping function used in the mapWithState
operation of a pair DStream (Scala)
or a JavaPairDStream (Java).
:: Experimental ::
Abstract class representing all the specifications of the DStream transformation
mapWithState
operation of a
pair DStream (Scala) or a
JavaPairDStream (Java).
Main entry point for Spark Streaming functionality.
This is a simple class that represents an absolute instant of time.
Helper object that creates instance of org.apache.spark.streaming.Duration representing a given number of milliseconds.
Helper object that creates instance of org.apache.spark.streaming.Duration representing a given number of minutes.
Helper object that creates instance of org.apache.spark.streaming.Duration representing a given number of seconds.
:: Experimental ::
Builder object for creating instances of StateSpec
that is used for specifying the parameters of the DStream transformation mapWithState
that is used for specifying the parameters of the DStream transformation
mapWithState
operation of a
pair DStream (Scala) or a
JavaPairDStream (Java).
StreamingContext object contains a number of utility functions related to the StreamingContext class.
Various implementations of DStream's.
Spark streaming receiver for Flume.
Kafka receiver for spark streaming,
MQTT receiver for Spark Streaming.
Twitter feed receiver for spark streaming.
Zeromq receiver for spark streaming.
Spark Streaming functionality. org.apache.spark.streaming.StreamingContext serves as the main entry point to Spark Streaming, while org.apache.spark.streaming.dstream.DStream is the data type representing a continuous sequence of RDDs, representing a continuous stream of data.
In addition, org.apache.spark.streaming.dstream.PairDStreamFunctions contains operations available only on DStreams of key-value pairs, such as
groupByKey
andreduceByKey
. These operations are automatically available on any DStream of the right type (e.g. DStream[(Int, Int)] through implicit conversions.For the Java API of Spark Streaming, take a look at the org.apache.spark.streaming.api.java.JavaStreamingContext which serves as the entry point, and the org.apache.spark.streaming.api.java.JavaDStream and the org.apache.spark.streaming.api.java.JavaPairDStream which have the DStream functionality.