Class | Description |
---|---|
AllWindowedStream<T,W extends Window> |
A
AllWindowedStream represents a data stream where the stream of elements is split into
windows based on a WindowAssigner . |
AsyncDataStream |
A helper class to apply
AsyncFunction to a data stream. |
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) . |
CoGroupedStreams<T1,T2> |
CoGroupedStreams represents two DataStreams that have been co-grouped. |
CoGroupedStreams.TaggedUnion<T1,T2> |
Internal class for implementing tagged union co-group.
|
CoGroupedStreams.UnionSerializer<T1,T2> | |
CoGroupedStreams.UnionSerializerConfigSnapshot<T1,T2> | Deprecated
this snapshot class is no longer in use, and is maintained only for backwards
compatibility.
|
CoGroupedStreams.UnionSerializerSnapshot<T1,T2> |
The
TypeSerializerSnapshot for the CoGroupedStreams.UnionSerializer . |
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.
|
DataStream<T> |
A DataStream represents a stream of elements of the same type.
|
DataStreamSink<T> |
A Stream Sink.
|
DataStreamSource<T> |
The DataStreamSource represents the starting point of a DataStream.
|
DataStreamUtils |
A collection of utilities for
DataStreams . |
IterativeStream<T> |
The iterative data stream represents the start of an iteration in a
DataStream . |
IterativeStream.ConnectedIterativeStreams<I,F> |
The
IterativeStream.ConnectedIterativeStreams represent a start of an iterative part of a streaming
program, where the original input of the iteration and the feedback of the iteration are
connected as in a ConnectedStreams . |
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 . |
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.
|
MultipleConnectedStreams |
This is a very basic and rough stub for a class connecting multiple input
DataStream s
into one, using MultipleInputStreamOperator . |
QueryableStateStream<K,V> |
Queryable state stream instance.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator represents a user defined transformation applied on a DataStream with one predefined output type. |
StreamProjection<IN> |
The result of
DataStream.project(int...) . |
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 . |
Enum | Description |
---|---|
AsyncDataStream.OutputMode |
Output mode for asynchronous operations.
|
Exception | Description |
---|---|
UnsupportedTimeCharacteristicException |
An exception that indicates that a time characteristic was used that is not supported in the
current operation.
|
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.