public abstract class InputDStream<T> extends DStream<T>
ReceiverInputDStream
as the parent class.
param: ssc_ Streaming context that will execute this input stream
Constructor and Description |
---|
InputDStream(StreamingContext ssc_,
scala.reflect.ClassTag<T> evidence$1) |
Modifier and Type | Method and Description |
---|---|
protected scala.Option<java.lang.String> |
baseScope()
The base scope associated with the operation that created this DStream.
|
scala.collection.immutable.List<DStream<?>> |
dependencies()
List of parent DStreams on which this DStream depends on
|
int |
id()
This is an unique identifier for the input stream.
|
Time |
lastValidTime() |
protected scala.Option<org.apache.spark.streaming.scheduler.RateController> |
rateController() |
Duration |
slideDuration()
Time interval after which the DStream generates a RDD
|
abstract void |
start()
Method called to start receiving data.
|
abstract void |
stop()
Method called to stop receiving data.
|
cache, checkpoint, checkpointData, checkpointDuration, compute, 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 InputDStream(StreamingContext ssc_, scala.reflect.ClassTag<T> evidence$1)
public Time lastValidTime()
public int id()
protected scala.Option<org.apache.spark.streaming.scheduler.RateController> rateController()
protected scala.Option<java.lang.String> baseScope()
For InputDStreams, we use the name of this DStream as the scope name. If an outer scope is given, we assume that it includes an alternative name for this stream.
public scala.collection.immutable.List<DStream<?>> dependencies()
DStream
dependencies
in class DStream<T>
public Duration slideDuration()
DStream
slideDuration
in class DStream<T>
public abstract void start()
public abstract void stop()