Class ReceiverInputDStream<T>

Object
org.apache.spark.streaming.dstream.DStream<T>
org.apache.spark.streaming.dstream.InputDStream<T>
org.apache.spark.streaming.dstream.ReceiverInputDStream<T>
Type Parameters:
T - Class type of the object of this stream
All Implemented Interfaces:
Serializable, org.apache.spark.internal.Logging, scala.Serializable

public abstract class ReceiverInputDStream<T> extends InputDStream<T>
Abstract class for defining any InputDStream that has to start a receiver on worker nodes to receive external data. Specific implementations of ReceiverInputDStream must define getReceiver() function that gets the receiver object of type Receiver that will be sent to the workers to receive data. param: _ssc Streaming context that will execute this input stream
See Also:
  • Constructor Details

    • ReceiverInputDStream

      public ReceiverInputDStream(StreamingContext _ssc, scala.reflect.ClassTag<T> evidence$1)
  • Method Details

    • compute

      public scala.Option<RDD<T>> compute(Time validTime)
      Description copied from class: DStream
      Method that generates an RDD for the given time
      Specified by:
      compute in class DStream<T>
      Parameters:
      validTime - (undocumented)
      Returns:
      (undocumented) Generates RDDs with blocks received by the receiver of this stream.
    • getReceiver

      public abstract Receiver<T> getReceiver()
      Gets the receiver object that will be sent to the worker nodes to receive data. This method needs to defined by any specific implementation of a ReceiverInputDStream.
      Returns:
      (undocumented)
    • start

      public void start()
      Description copied from class: InputDStream
      Method called to start receiving data. Subclasses must implement this method.
      Specified by:
      start in class InputDStream<T>
    • stop

      public void stop()
      Description copied from class: InputDStream
      Method called to stop receiving data. Subclasses must implement this method.
      Specified by:
      stop in class InputDStream<T>