Uses of Package
org.apache.flink.streaming.api.transformations
-
Classes in org.apache.flink.streaming.api.transformations used by org.apache.flink.streaming.api.datastream Class Description LegacySinkTransformation This Transformation represents a stream Sink.PhysicalTransformation ATransformation
that creates a physical operation.SideOutputTransformation This transformation represents a selection of a side output of an upstream operation with a givenOutputTag
. -
Classes in org.apache.flink.streaming.api.transformations used by org.apache.flink.streaming.api.environment Class Description CacheTransformation When in batch mode, theCacheTransformation
represents the intermediate result of the upper stream should be cached when it is computed at the first time. -
Classes in org.apache.flink.streaming.api.transformations used by org.apache.flink.streaming.api.graph Class Description StreamExchangeMode The data exchange mode between operators duringStreamGraph
generation. -
Classes in org.apache.flink.streaming.api.transformations used by org.apache.flink.streaming.api.transformations Class Description AbstractBroadcastStateTransformation Base class for Broadcast State transformations.AbstractMultipleInputTransformation Base class for transformations representing the application of aMultipleInputStreamOperator
to inputTransformations
.KeyedMultipleInputTransformation AbstractMultipleInputTransformation
implementation for keyed streams.MultipleInputTransformation AbstractMultipleInputTransformation
implementation for non-keyed streams.PhysicalTransformation ATransformation
that creates a physical operation.StreamExchangeMode The data exchange mode between operators duringStreamGraph
generation.TransformationWithLineage ATransformation
that contains lineage information.WithBoundedness An interface to be implemented by transformations that have explicitly setBoundedness
. -
Classes in org.apache.flink.streaming.api.transformations used by org.apache.flink.streaming.runtime.translators Class Description AbstractMultipleInputTransformation Base class for transformations representing the application of aMultipleInputStreamOperator
to inputTransformations
.BroadcastStateTransformation A non-keyedAbstractBroadcastStateTransformation
.CacheTransformation When in batch mode, theCacheTransformation
represents the intermediate result of the upper stream should be cached when it is computed at the first time.GlobalCommitterTransform Transformation for global committer.KeyedBroadcastStateTransformation A keyedAbstractBroadcastStateTransformation
.LegacySinkTransformation This Transformation represents a stream Sink.LegacySourceTransformation This represents a Source.OneInputTransformation This Transformation represents the application of aOneInputStreamOperator
to one inputTransformation
.PartitionTransformation This transformation represents a change of partitioning of the input elements.ReduceTransformation ATransformation
that describes a reduce operation on aKeyedStream
.SideOutputTransformation This transformation represents a selection of a side output of an upstream operation with a givenOutputTag
.SinkTransformation ATransformation
forSink
.SourceTransformation APhysicalTransformation
forSource
.TimestampsAndWatermarksTransformation TwoInputTransformation This Transformation represents the application of aTwoInputStreamOperator
to two inputTransformations
.UnionTransformation This transformation represents a union of several inputTransformations
.