org.apache.spark

streaming

package 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 and reduceByKey. These operations are automatically available on any DStream of the right type (e.g. DStream[(Int, Int)] through implicit conversions when you import org.apache.spark.streaming.StreamingContext._.

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.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. streaming
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. case class Duration(millis: Long) extends Product with Serializable

  2. class StreamingContext extends Logging

    Main entry point for Spark Streaming functionality.

  3. case class Time(millis: Long) extends Product with Serializable

    This is a simple class that represents an absolute instant of time.

Value Members

  1. object Milliseconds

    Helper object that creates instance of org.apache.spark.streaming.Duration representing a given number of milliseconds.

  2. object Minutes

    Helper object that creates instance of org.apache.spark.streaming.Duration representing a given number of minutes.

  3. object Seconds

    Helper object that creates instance of org.apache.spark.streaming.Duration representing a given number of seconds.

  4. object StreamingContext extends Logging

    StreamingContext object contains a number of utility functions related to the StreamingContext class.

  5. object Time extends Serializable

  6. package api

  7. package dstream

  8. package receivers

  9. package scheduler

Inherited from AnyRef

Inherited from Any

Ungrouped