Class SideOutputDataStream<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.datastream.DataStream<T>
-
- org.apache.flink.streaming.api.datastream.SideOutputDataStream<T>
-
- Type Parameters:
T
- The type of the elements in this stream.
@Public public class SideOutputDataStream<T> extends DataStream<T>
ASideOutputDataStream
represents aDataStream
that contains elements that are emitted from upstream into a side output with some tag.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.streaming.api.datastream.DataStream
DataStream.Collector<T>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.api.datastream.DataStream
environment, transformation
-
-
Constructor Summary
Constructors Constructor Description SideOutputDataStream(StreamExecutionEnvironment environment, SideOutputTransformation<T> transformation)
Creates a newSideOutputDataStream
in the given execution environment.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description CachedDataStream<T>
cache()
Caches the intermediate result of the transformation.-
Methods inherited from class org.apache.flink.streaming.api.datastream.DataStream
addSink, assignTimestampsAndWatermarks, broadcast, broadcast, clean, coGroup, collectAsync, collectAsync, connect, connect, countWindowAll, countWindowAll, doTransform, executeAndCollect, executeAndCollect, executeAndCollect, executeAndCollect, filter, flatMap, flatMap, forward, fullWindowPartition, getExecutionConfig, getExecutionEnvironment, getId, getMinResources, getParallelism, getPreferredResources, getTransformation, getType, global, join, keyBy, keyBy, keyBy, map, map, partitionCustom, print, print, printToErr, printToErr, process, process, project, rebalance, rescale, setConnectionType, shuffle, sinkTo, sinkTo, transform, transform, union, windowAll, writeToSocket, writeUsingOutputFormat
-
-
-
-
Constructor Detail
-
SideOutputDataStream
public SideOutputDataStream(StreamExecutionEnvironment environment, SideOutputTransformation<T> transformation)
Creates a newSideOutputDataStream
in the given execution environment.- Parameters:
environment
- The StreamExecutionEnvironmenttransformation
- The SideOutputTransformation
-
-
Method Detail
-
cache
@PublicEvolving public CachedDataStream<T> cache()
Caches the intermediate result of the transformation. Only support bounded streams and currently only block mode is supported. The cache is generated lazily at the first time the intermediate result is computed. The cache will be clear whenCachedDataStream.invalidate()
called or theStreamExecutionEnvironment
close.- Returns:
- CachedDataStream that can use in later job to reuse the cached intermediate result.
-
-