| AllWindowedStream |
A AllWindowedStream represents a data stream where the stream of elements is split into
windows based on a WindowAssigner.
|
| BroadcastConnectedStream |
A BroadcastConnectedStream represents the result of connecting a keyed or non-keyed stream, with
a BroadcastStream with broadcast
state(s).
|
| BroadcastStream |
A BroadcastStream is a stream with broadcast state(s).
|
| CachedDataStream |
|
| CoGroupedStreams |
CoGroupedStreams represents two DataStreams that have been co-grouped.
|
| CoGroupedStreams.UnionSerializer |
TypeSerializer for TaggedUnion.
|
| CoGroupedStreams.Where |
CoGrouped streams that have the key for one side defined.
|
| CoGroupedStreams.Where.EqualTo |
A co-group operation that has KeySelectors defined for both inputs.
|
| CoGroupedStreams.WithWindow |
A co-group operation that has KeySelectors defined for both inputs as
well as a WindowAssigner.
|
| ConnectedStreams |
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 |
A DataStream represents a stream of elements of the same type.
|
| DataStream.Collector |
|
| DataStreamSink |
A Stream Sink.
|
| DataStreamSource |
The DataStreamSource represents the starting point of a DataStream.
|
| JoinedStreams |
JoinedStreams represents two DataStreams that have been joined.
|
| JoinedStreams.Where |
Joined streams that have the key for one side defined.
|
| JoinedStreams.Where.EqualTo |
A join operation that has KeySelectors defined for both inputs.
|
| JoinedStreams.WithWindow |
A join operation that has KeySelectors defined for both inputs as well as
a WindowAssigner.
|
| KeyedStream |
A KeyedStream represents a DataStream on which operator state is partitioned by
key using a provided KeySelector.
|
| KeyedStream.IntervalJoin |
Perform a join over a time interval.
|
| KeyedStream.IntervalJoined |
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.
|
| PartitionWindowedStream |
PartitionWindowedStream represents a data stream that collects all records of each
partition separately into a full window.
|
| QueryableStateStream |
Deprecated.
|
| SideOutputDataStream |
|
| SingleOutputStreamOperator |
SingleOutputStreamOperator represents a user defined transformation applied on a DataStream with one predefined output type.
|
| WindowedStream |
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.
|