public class QueueInputDStream<T> extends InputDStream<T>
Constructor and Description |
---|
QueueInputDStream(StreamingContext ssc,
scala.collection.mutable.Queue<RDD<T>> queue,
boolean oneAtATime,
RDD<T> defaultRDD,
scala.reflect.ClassTag<T> evidence$1) |
Modifier and Type | Method and Description |
---|---|
scala.Option<RDD<T>> |
compute(Time validTime)
Method that generates a RDD for the given time
|
scala.collection.mutable.Queue<RDD<T>> |
queue() |
void |
start()
Method called to start receiving data.
|
void |
stop()
Method called to stop receiving data.
|
dependencies, isTimeValid, lastValidTime, slideDuration
cache, 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, zeroTime
equals, 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 void start()
InputDStream
start
in class InputDStream<T>
public void stop()
InputDStream
stop
in class InputDStream<T>