public class ForEachDStream<T> extends DStream<scala.runtime.BoxedUnit>
Constructor and Description |
---|
ForEachDStream(DStream<T> parent,
scala.Function2<RDD<T>,Time,scala.runtime.BoxedUnit> foreachFunc,
scala.reflect.ClassTag<T> evidence$1) |
Modifier and Type | Method and Description |
---|---|
scala.Option<RDD<scala.runtime.BoxedUnit>> |
compute(Time validTime)
Method that generates a RDD for the given time
|
scala.collection.immutable.List<DStream<T>> |
dependencies() |
scala.Option<Job> |
generateJob(Time time)
Generate a SparkStreaming job for the given time.
|
Duration |
slideDuration()
Time interval after which the DStream generates a RDD
|
cache, checkpoint, checkpointData, checkpointDuration, clearCheckpointData, clearMetadata, context, count, countByValue, countByValueAndWindow, countByWindow, creationSite, filter, flatMap, foreach, foreach, foreachRDD, foreachRDD, generatedRDDs, getCreationSite, getOrCompute, glom, graph, initialize, isInitialized, isTimeValid, 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 Duration slideDuration()
DStream
slideDuration
in class DStream<scala.runtime.BoxedUnit>
public scala.Option<RDD<scala.runtime.BoxedUnit>> compute(Time validTime)
DStream
public scala.Option<Job> generateJob(Time time)
DStream
generateJob
in class DStream<scala.runtime.BoxedUnit>