| AllWindowedStream<T,W extends Window> |
A AllWindowedStream represents a data stream where the stream of elements is split into
windows based on a WindowAssigner.
|
| BroadcastConnectedStream<IN1,IN2> |
A BroadcastConnectedStream represents the result of connecting a keyed or non-keyed stream, with
a BroadcastStream with broadcast
state(s).
|
| BroadcastStream<T> |
A BroadcastStream is a stream with broadcast state(s).
|
| CachedDataStream<T> |
|
| CoGroupedStreams<T1,T2> |
CoGroupedStreams represents two DataStreams that have been co-grouped.
|
| CoGroupedStreams.UnionSerializer<T1,T2> |
TypeSerializer for TaggedUnion.
|
| CoGroupedStreams.UnionSerializerSnapshot<T1,T2> |
|
| CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> |
A co-group operation that has KeySelectors defined for both inputs as
well as a WindowAssigner.
|
| ConnectedStreams<IN1,IN2> |
ConnectedStreams represent two connected streams of (possibly) different data types.
|
| CustomSinkOperatorUidHashes |
This class is responsible to hold operator Uid hashes from the common operators of the sink.
|
| CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder |
|
| DataStream<T> |
A DataStream represents a stream of elements of the same type.
|
| DataStream.Collector<T> |
|
| DataStreamSink<T> |
A Stream Sink.
|
| DataStreamSource<T> |
The DataStreamSource represents the starting point of a DataStream.
|
| JoinedStreams<T1,T2> |
JoinedStreams represents two DataStreams that have been joined.
|
| JoinedStreams.WithWindow<T1,T2,KEY,W extends Window> |
A join operation that has KeySelectors defined for both inputs as well as
a WindowAssigner.
|
| KeyedPartitionWindowedStream<T,KEY> |
|
| KeyedStream<T,KEY> |
A KeyedStream represents a DataStream on which operator state is partitioned by
key using a provided KeySelector.
|
| KeyedStream.IntervalJoin<T1,T2,KEY> |
Perform a join over a time interval.
|
| KeyedStream.IntervalJoined<IN1,IN2,KEY> |
IntervalJoined is a container for two streams that have keys for both sides as well as the
time boundaries over which elements should be joined.
|
| NonKeyedPartitionWindowedStream<T> |
|
| QueryableStateStream<K,V> |
Deprecated.
|
| SideOutputDataStream<T> |
|
| SingleOutputStreamOperator<T> |
SingleOutputStreamOperator represents a user defined transformation applied on a DataStream with one predefined output type.
|
| StreamProjection<IN> |
|
| WindowedStream<T,K,W extends Window> |
A WindowedStream represents a data stream where elements are grouped by key, and for each
key, the stream of elements is split into windows based on a WindowAssigner.
|