Class ConstantInputDStream<T>
Object
org.apache.spark.streaming.dstream.DStream<T>
org.apache.spark.streaming.dstream.InputDStream<T>
org.apache.spark.streaming.dstream.ConstantInputDStream<T>
- All Implemented Interfaces:
Serializable
,org.apache.spark.internal.Logging
An input stream that always returns the same RDD on each time step. Useful for testing.
- See Also:
-
Nested Class Summary
Nested classes/interfaces inherited from interface org.apache.spark.internal.Logging
org.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
-
Constructor Summary
ConstructorDescriptionConstantInputDStream
(StreamingContext _ssc, RDD<T> rdd, scala.reflect.ClassTag<T> evidence$1) -
Method Summary
Methods inherited from class org.apache.spark.streaming.dstream.InputDStream
dependencies, id, slideDuration
Methods inherited from class org.apache.spark.streaming.dstream.DStream
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
Methods inherited from class java.lang.Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.apache.spark.internal.Logging
initializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, isTraceEnabled, log, logDebug, logDebug, logDebug, logDebug, logError, logError, logError, logError, logInfo, logInfo, logInfo, logInfo, logName, LogStringContext, logTrace, logTrace, logTrace, logTrace, logWarning, logWarning, logWarning, logWarning, org$apache$spark$internal$Logging$$log_, org$apache$spark$internal$Logging$$log__$eq, withLogContext
-
Constructor Details
-
ConstantInputDStream
public ConstantInputDStream(StreamingContext _ssc, RDD<T> rdd, scala.reflect.ClassTag<T> evidence$1)
-
-
Method Details
-
compute
Description copied from class:DStream
Method that generates an RDD for the given time -
start
public void start()Description copied from class:InputDStream
Method called to start receiving data. Subclasses must implement this method.- Specified by:
start
in classInputDStream<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 classInputDStream<T>
-