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.| Constructor and Description |
|---|
ReceiverInputDStream(StreamingContext ssc_,
scala.reflect.ClassTag<T> evidence$1) |
| Modifier and Type | Method and Description |
|---|---|
scala.Option<RDD<T>> |
compute(Time validTime)
Generates RDDs with blocks received by the receiver of this stream.
|
abstract Receiver<T> |
getReceiver()
Gets the receiver object that will be sent to the worker nodes
to receive data.
|
int |
id()
This is an unique identifier for the receiver input stream.
|
void |
start()
Method called to start receiving data.
|
void |
stop()
Method called to stop receiving data.
|
dependencies, isTimeValid, lastValidTime, slideDurationcache, checkpoint, checkpointData, checkpointDuration, clearCheckpointData, clearMetadata, context, count, countByValue, countByValueAndWindow, countByWindow, creationSite, filter, flatMap, foreach, foreach, foreachRDD, foreachRDD, generatedRDDs, generateJob, getCreationSite, getOrCompute, glom, graph, initialize, isInitialized, map, mapPartitions, mustCheckpoint, parentRememberDuration, persist, persist, print, reduce, reduceByWindow, reduceByWindow, register, remember, rememberDuration, repartition, restoreCheckpointData, saveAsObjectFiles, saveAsTextFiles, setContext, setGraph, slice, slice, ssc, storageLevel, transform, transform, transformWith, transformWith, union, updateCheckpointData, validate, window, window, zeroTimeequals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitinitializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarningpublic ReceiverInputDStream(StreamingContext ssc_, scala.reflect.ClassTag<T> evidence$1)
public int id()
public abstract Receiver<T> getReceiver()
public void start()
InputDStreamstart in class InputDStream<T>public void stop()
InputDStreamstop in class InputDStream<T>