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 SummaryNested classes/interfaces inherited from interface org.apache.spark.internal.Loggingorg.apache.spark.internal.Logging.LogStringContext, org.apache.spark.internal.Logging.SparkShellLoggingFilter
- 
Constructor SummaryConstructorsConstructorDescriptionConstantInputDStream(StreamingContext _ssc, RDD<T> rdd, scala.reflect.ClassTag<T> evidence$1) 
- 
Method SummaryMethods inherited from class org.apache.spark.streaming.dstream.InputDStreamdependencies, id, slideDurationMethods inherited from class org.apache.spark.streaming.dstream.DStreamcache, 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, windowMethods inherited from class java.lang.Objectequals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.spark.internal.LogginginitializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, isTraceEnabled, log, logBasedOnLevel, 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- 
ConstantInputDStreampublic ConstantInputDStream(StreamingContext _ssc, RDD<T> rdd, scala.reflect.ClassTag<T> evidence$1) 
 
- 
- 
Method Details- 
computeDescription copied from class:DStreamMethod that generates an RDD for the given time
- 
startpublic void start()Description copied from class:InputDStreamMethod called to start receiving data. Subclasses must implement this method.- Specified by:
- startin class- InputDStream<T>
 
- 
stoppublic void stop()Description copied from class:InputDStreamMethod called to stop receiving data. Subclasses must implement this method.- Specified by:
- stopin class- InputDStream<T>
 
 
-