AbstractBroadcastStateTransformation<IN1,IN2,OUT> |
Base class for Broadcast State transformations.
|
AbstractMultipleInputTransformation<OUT> |
|
BroadcastStateTransformation<IN1,IN2,OUT> |
|
CacheTransformation<T> |
When in batch mode, the CacheTransformation represents the intermediate result of the
upper stream should be cached when it is computed at the first time.
|
GlobalCommitterTransform<CommT> |
Transformation for global committer.
|
KeyedBroadcastStateTransformation<KEY,IN1,IN2,OUT> |
|
KeyedMultipleInputTransformation<OUT> |
|
LegacySinkTransformation<T> |
This Transformation represents a stream Sink.
|
LegacySourceTransformation<T> |
This represents a Source.
|
MultipleInputTransformation<OUT> |
|
OneInputTransformation<IN,OUT> |
|
PartitionTransformation<T> |
This transformation represents a change of partitioning of the input elements.
|
PhysicalTransformation<T> |
A Transformation that creates a physical operation.
|
ReduceTransformation<IN,K> |
A Transformation that describes a reduce operation on a KeyedStream .
|
SideOutputTransformation<T> |
This transformation represents a selection of a side output of an upstream operation with a given
OutputTag .
|
SinkTransformation<InputT,OutputT> |
A Transformation for Sink .
|
SourceTransformation<OUT,SplitT extends org.apache.flink.api.connector.source.SourceSplit,EnumChkT> |
|
SourceTransformationWrapper<T> |
This Transformation is a phantom transformation which is used to expose a default parallelism to
downstream.
|
TimestampsAndWatermarksTransformation<IN> |
|
TransformationWithLineage<T> |
A Transformation that contains lineage information.
|
TwoInputTransformation<IN1,IN2,OUT> |
|
UnionTransformation<T> |
This transformation represents a union of several input Transformations .
|