public abstract class ReceiverInputDStream<T> extends InputDStream<T>
InputDStream
that has to start a receiver on worker nodes to receive external data.
Specific implementations of ReceiverInputDStream must
define the 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 streamConstructor and Description |
---|
ReceiverInputDStream(StreamingContext ssc_,
scala.reflect.ClassTag<T> evidence$1) |
Modifier and Type | Method and Description |
---|---|
scala.Option<RDD<T>> |
compute(Time validTime)
Method that generates a RDD for the given time
|
abstract Receiver<T> |
getReceiver()
Gets the receiver object that will be sent to the worker nodes
to receive data.
|
protected scala.Option<org.apache.spark.streaming.scheduler.RateController> |
rateController()
Asynchronously maintains & sends new rate limits to the receiver through the receiver tracker.
|
void |
start()
Method called to start receiving data.
|
void |
stop()
Method called to stop receiving data.
|
baseScope, dependencies, id, lastValidTime, slideDuration
cache, checkpoint, checkpointData, checkpointDuration, context, count, countByValue, countByValueAndWindow, countByWindow, createRDDWithLocalProperties, creationSite, filter, flatMap, foreach, foreach, foreachRDD, foreachRDD, generatedRDDs, glom, graph, map, mapPartitions, mustCheckpoint, persist, persist, print, print, reduce, reduceByWindow, reduceByWindow, rememberDuration, repartition, saveAsObjectFiles, saveAsTextFiles, slice, slice, ssc, storageLevel, toPairDStreamFunctions, transform, transform, transformWith, transformWith, union, window, window, zeroTime
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public ReceiverInputDStream(StreamingContext ssc_, scala.reflect.ClassTag<T> evidence$1)
protected scala.Option<org.apache.spark.streaming.scheduler.RateController> rateController()
rateController
in class InputDStream<T>
public abstract Receiver<T> getReceiver()
public void start()
InputDStream
start
in class InputDStream<T>
public void stop()
InputDStream
stop
in class InputDStream<T>