public interface JavaDStreamLike<T,This extends JavaDStreamLike<T,This,R>,R extends JavaRDDLike<T,R>>
extends scala.Serializable
Modifier and Type | Method and Description |
---|---|
DStream<T> |
checkpoint(Duration interval)
Enable periodic checkpointing of RDDs of this DStream.
|
scala.reflect.ClassTag<T> |
classTag() |
StreamingContext |
context()
Return the
StreamingContext associated with this DStream |
JavaDStream<Long> |
count()
Return a new DStream in which each RDD has a single element generated by counting each RDD
of this DStream.
|
JavaPairDStream<T,Long> |
countByValue()
Return a new DStream in which each RDD contains the counts of each distinct value in
each RDD of this DStream.
|
JavaPairDStream<T,Long> |
countByValue(int numPartitions)
Return a new DStream in which each RDD contains the counts of each distinct value in
each RDD of this DStream.
|
JavaPairDStream<T,Long> |
countByValueAndWindow(Duration windowDuration,
Duration slideDuration)
Return a new DStream in which each RDD contains the count of distinct elements in
RDDs in a sliding window over this DStream.
|
JavaPairDStream<T,Long> |
countByValueAndWindow(Duration windowDuration,
Duration slideDuration,
int numPartitions)
Return a new DStream in which each RDD contains the count of distinct elements in
RDDs in a sliding window over this DStream.
|
JavaDStream<Long> |
countByWindow(Duration windowDuration,
Duration slideDuration)
Return a new DStream in which each RDD has a single element generated by counting the number
of elements in a window over this DStream.
|
DStream<T> |
dstream() |
<U> JavaDStream<U> |
flatMap(FlatMapFunction<T,U> f)
Return a new DStream by applying a function to all elements of this DStream,
and then flattening the results
|
<K2,V2> JavaPairDStream<K2,V2> |
flatMapToPair(PairFlatMapFunction<T,K2,V2> f)
Return a new DStream by applying a function to all elements of this DStream,
and then flattening the results
|
void |
foreachRDD(VoidFunction<R> foreachFunc)
Apply a function to each RDD in this DStream.
|
void |
foreachRDD(VoidFunction2<R,Time> foreachFunc)
Apply a function to each RDD in this DStream.
|
JavaDStream<java.util.List<T>> |
glom()
Return a new DStream in which each RDD is generated by applying glom() to each RDD of
this DStream.
|
<U> JavaDStream<U> |
map(Function<T,U> f)
Return a new DStream by applying a function to all elements of this DStream.
|
<U> JavaDStream<U> |
mapPartitions(FlatMapFunction<java.util.Iterator<T>,U> f)
Return a new DStream in which each RDD is generated by applying mapPartitions() to each RDDs
of this DStream.
|
<K2,V2> JavaPairDStream<K2,V2> |
mapPartitionsToPair(PairFlatMapFunction<java.util.Iterator<T>,K2,V2> f)
Return a new DStream in which each RDD is generated by applying mapPartitions() to each RDDs
of this DStream.
|
<K2,V2> JavaPairDStream<K2,V2> |
mapToPair(PairFunction<T,K2,V2> f)
Return a new DStream by applying a function to all elements of this DStream.
|
void |
print()
Print the first ten elements of each RDD generated in this DStream.
|
void |
print(int num)
Print the first num elements of each RDD generated in this DStream.
|
JavaDStream<T> |
reduce(Function2<T,T,T> f)
Return a new DStream in which each RDD has a single element generated by reducing each RDD
of this DStream.
|
JavaDStream<T> |
reduceByWindow(Function2<T,T,T> reduceFunc,
Duration windowDuration,
Duration slideDuration)
Return a new DStream in which each RDD has a single element generated by reducing all
elements in a sliding window over this DStream.
|
JavaDStream<T> |
reduceByWindow(Function2<T,T,T> reduceFunc,
Function2<T,T,T> invReduceFunc,
Duration windowDuration,
Duration slideDuration)
Return a new DStream in which each RDD has a single element generated by reducing all
elements in a sliding window over this DStream.
|
JavaDStream<Long> |
scalaIntToJavaLong(DStream<Object> in) |
java.util.List<R> |
slice(Time fromTime,
Time toTime)
Return all the RDDs between 'fromDuration' to 'toDuration' (both included)
|
<U> JavaDStream<U> |
transform(Function<R,JavaRDD<U>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream.
|
<U> JavaDStream<U> |
transform(Function2<R,Time,JavaRDD<U>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream.
|
<K2,V2> JavaPairDStream<K2,V2> |
transformToPair(Function<R,JavaPairRDD<K2,V2>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream.
|
<K2,V2> JavaPairDStream<K2,V2> |
transformToPair(Function2<R,Time,JavaPairRDD<K2,V2>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream.
|
<U,W> JavaDStream<W> |
transformWith(JavaDStream<U> other,
Function3<R,JavaRDD<U>,Time,JavaRDD<W>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream and 'other' DStream.
|
<K2,V2,W> JavaDStream<W> |
transformWith(JavaPairDStream<K2,V2> other,
Function3<R,JavaPairRDD<K2,V2>,Time,JavaRDD<W>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream and 'other' DStream.
|
<U,K2,V2> JavaPairDStream<K2,V2> |
transformWithToPair(JavaDStream<U> other,
Function3<R,JavaRDD<U>,Time,JavaPairRDD<K2,V2>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream and 'other' DStream.
|
<K2,V2,K3,V3> |
transformWithToPair(JavaPairDStream<K2,V2> other,
Function3<R,JavaPairRDD<K2,V2>,Time,JavaPairRDD<K3,V3>> transformFunc)
Return a new DStream in which each RDD is generated by applying a function
on each RDD of 'this' DStream and 'other' DStream.
|
R |
wrapRDD(RDD<T> in) |
DStream<T> checkpoint(Duration interval)
interval
- Time interval after which generated RDD will be checkpointedscala.reflect.ClassTag<T> classTag()
StreamingContext context()
StreamingContext
associated with this DStreamJavaDStream<Long> count()
JavaPairDStream<T,Long> countByValue()
JavaPairDStream<T,Long> countByValue(int numPartitions)
numPartitions
partitions.numPartitions
- number of partitions of each RDD in the new DStream.JavaPairDStream<T,Long> countByValueAndWindow(Duration windowDuration, Duration slideDuration)
windowDuration
- width of the window; must be a multiple of this DStream's
batching intervalslideDuration
- sliding interval of the window (i.e., the interval after which
the new DStream will generate RDDs); must be a multiple of this
DStream's batching intervalJavaPairDStream<T,Long> countByValueAndWindow(Duration windowDuration, Duration slideDuration, int numPartitions)
numPartitions
partitions.windowDuration
- width of the window; must be a multiple of this DStream's
batching intervalslideDuration
- sliding interval of the window (i.e., the interval after which
the new DStream will generate RDDs); must be a multiple of this
DStream's batching intervalnumPartitions
- number of partitions of each RDD in the new DStream.JavaDStream<Long> countByWindow(Duration windowDuration, Duration slideDuration)
windowDuration
- (undocumented)slideDuration
- (undocumented)<U> JavaDStream<U> flatMap(FlatMapFunction<T,U> f)
f
- (undocumented)<K2,V2> JavaPairDStream<K2,V2> flatMapToPair(PairFlatMapFunction<T,K2,V2> f)
f
- (undocumented)void foreachRDD(VoidFunction<R> foreachFunc)
foreachFunc
- (undocumented)void foreachRDD(VoidFunction2<R,Time> foreachFunc)
foreachFunc
- (undocumented)JavaDStream<java.util.List<T>> glom()
<U> JavaDStream<U> map(Function<T,U> f)
<U> JavaDStream<U> mapPartitions(FlatMapFunction<java.util.Iterator<T>,U> f)
f
- (undocumented)<K2,V2> JavaPairDStream<K2,V2> mapPartitionsToPair(PairFlatMapFunction<java.util.Iterator<T>,K2,V2> f)
f
- (undocumented)<K2,V2> JavaPairDStream<K2,V2> mapToPair(PairFunction<T,K2,V2> f)
void print()
void print(int num)
num
- (undocumented)JavaDStream<T> reduce(Function2<T,T,T> f)
f
- (undocumented)JavaDStream<T> reduceByWindow(Function2<T,T,T> reduceFunc, Duration windowDuration, Duration slideDuration)
reduceFunc
- associative and commutative reduce functionwindowDuration
- width of the window; must be a multiple of this DStream's
batching intervalslideDuration
- sliding interval of the window (i.e., the interval after which
the new DStream will generate RDDs); must be a multiple of this
DStream's batching intervalJavaDStream<T> reduceByWindow(Function2<T,T,T> reduceFunc, Function2<T,T,T> invReduceFunc, Duration windowDuration, Duration slideDuration)
reduceFunc
- associative and commutative reduce functioninvReduceFunc
- inverse reduce function; such that for all y, invertible x:
invReduceFunc(reduceFunc(x, y), x) = y
windowDuration
- width of the window; must be a multiple of this DStream's
batching intervalslideDuration
- sliding interval of the window (i.e., the interval after which
the new DStream will generate RDDs); must be a multiple of this
DStream's batching intervalJavaDStream<Long> scalaIntToJavaLong(DStream<Object> in)
java.util.List<R> slice(Time fromTime, Time toTime)
fromTime
- (undocumented)toTime
- (undocumented)<U> JavaDStream<U> transform(Function<R,JavaRDD<U>> transformFunc)
transformFunc
- (undocumented)<U> JavaDStream<U> transform(Function2<R,Time,JavaRDD<U>> transformFunc)
transformFunc
- (undocumented)<K2,V2> JavaPairDStream<K2,V2> transformToPair(Function<R,JavaPairRDD<K2,V2>> transformFunc)
transformFunc
- (undocumented)<K2,V2> JavaPairDStream<K2,V2> transformToPair(Function2<R,Time,JavaPairRDD<K2,V2>> transformFunc)
transformFunc
- (undocumented)<U,W> JavaDStream<W> transformWith(JavaDStream<U> other, Function3<R,JavaRDD<U>,Time,JavaRDD<W>> transformFunc)
other
- (undocumented)transformFunc
- (undocumented)<K2,V2,W> JavaDStream<W> transformWith(JavaPairDStream<K2,V2> other, Function3<R,JavaPairRDD<K2,V2>,Time,JavaRDD<W>> transformFunc)
other
- (undocumented)transformFunc
- (undocumented)<U,K2,V2> JavaPairDStream<K2,V2> transformWithToPair(JavaDStream<U> other, Function3<R,JavaRDD<U>,Time,JavaPairRDD<K2,V2>> transformFunc)
other
- (undocumented)transformFunc
- (undocumented)<K2,V2,K3,V3> JavaPairDStream<K3,V3> transformWithToPair(JavaPairDStream<K2,V2> other, Function3<R,JavaPairRDD<K2,V2>,Time,JavaPairRDD<K3,V3>> transformFunc)
other
- (undocumented)transformFunc
- (undocumented)