public class ConstantInputDStream<T> extends InputDStream<T>
Constructor and Description |
---|
ConstantInputDStream(StreamingContext _ssc,
RDD<T> rdd,
scala.reflect.ClassTag<T> evidence$1) |
Modifier and Type | Method and Description |
---|---|
scala.Option<RDD<T>> |
compute(Time validTime)
Method that generates an RDD for the given time
|
void |
start()
Method called to start receiving data.
|
void |
stop()
Method called to stop receiving data.
|
dependencies, id, slideDuration
cache, checkpoint, context, count, countByValue, countByValueAndWindow, countByWindow, filter, flatMap, foreachRDD, foreachRDD, glom, map, mapPartitions, persist, persist, print, print, reduce, reduceByWindow, reduceByWindow, repartition, saveAsObjectFiles, saveAsTextFiles, slice, slice, toPairDStreamFunctions, transform, transform, transformWith, transformWith, union, window, window
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
$init$, initializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, initLock, isTraceEnabled, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning, org$apache$spark$internal$Logging$$log__$eq, org$apache$spark$internal$Logging$$log_, uninitialize
public ConstantInputDStream(StreamingContext _ssc, RDD<T> rdd, scala.reflect.ClassTag<T> evidence$1)
public scala.Option<RDD<T>> compute(Time validTime)
DStream
public void start()
InputDStream
start
in class InputDStream<T>
public void stop()
InputDStream
stop
in class InputDStream<T>