Interface | Description |
---|---|
PartitionWindowedStream<T> |
PartitionWindowedStream represents a data stream that collects all records of each
partition separately into a full window. |
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) . |
CachedDataStream<T> |
CachedDataStream represents a DataStream whose intermediate result will be cached
at the first time when it is computed. |
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.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.
|
CustomSinkOperatorUidHashes |
This class is responsible to hold operator Uid hashes from the common operators of the sink.
|
CustomSinkOperatorUidHashes.SinkOperatorUidHashesBuilder |
Builder to construct
CustomSinkOperatorUidHashes . |
DataStream<T> |
A DataStream represents a stream of elements of the same type.
|
DataStream.Collector<T> |
This class acts as an accessor to elements collected via
DataStream.collectAsync(Collector) . |
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> | Deprecated
This method is deprecated since Flink 1.19.
|
IterativeStream.ConnectedIterativeStreams<I,F> | Deprecated
This method is deprecated since Flink 1.19.
|
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> |
KeyedPartitionWindowedStream represents a data stream that collects all records with the
same key separately into a full window. |
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 . |
NonKeyedPartitionWindowedStream<T> |
NonKeyedPartitionWindowedStream represents a data stream that collects all records of
each subtask separately into a full window. |
QueryableStateStream<K,V> | Deprecated
The Queryable State feature is deprecated since Flink 1.18, and will be removed in a
future Flink major version.
|
SideOutputDataStream<T> |
A
SideOutputDataStream represents a DataStream that contains elements that are
emitted from upstream into a side output with some tag. |
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–2024 The Apache Software Foundation. All rights reserved.