Class TimestampsAndWatermarksTransformation<IN>
- java.lang.Object
-
- org.apache.flink.api.dag.Transformation<T>
-
- org.apache.flink.streaming.api.transformations.PhysicalTransformation<IN>
-
- org.apache.flink.streaming.api.transformations.TimestampsAndWatermarksTransformation<IN>
-
- Type Parameters:
IN
- The input and output type of the transformation.
@Internal public class TimestampsAndWatermarksTransformation<IN> extends PhysicalTransformation<IN>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.api.dag.Transformation
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
-
-
Constructor Summary
Constructors Constructor Description TimestampsAndWatermarksTransformation(String name, int parallelism, Transformation<IN> input, WatermarkStrategy<IN> watermarkStrategy, boolean parallelismConfigured)
Creates a newTransformation
with the given name, output type and parallelism.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description ChainingStrategy
getChainingStrategy()
List<Transformation<?>>
getInputs()
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.TypeInformation<IN>
getInputType()
Returns theTypeInformation
for the elements of the input.protected List<Transformation<?>>
getTransitivePredecessorsInternal()
Returns all transitive predecessorTransformation
s of thisTransformation
.WatermarkStrategy<IN>
getWatermarkStrategy()
Returns theWatermarkStrategy
to use.void
setChainingStrategy(ChainingStrategy chainingStrategy)
Sets the chaining strategy of thisTransformation
.-
Methods inherited from class org.apache.flink.streaming.api.transformations.PhysicalTransformation
isSupportsConcurrentExecutionAttempts, setSupportsConcurrentExecutionAttempts
-
Methods inherited from class org.apache.flink.api.dag.Transformation
declareManagedMemoryUseCaseAtOperatorScope, declareManagedMemoryUseCaseAtSlotScope, equals, getAttribute, getBufferTimeout, getCoLocationGroupKey, getDescription, getId, getManagedMemoryOperatorScopeUseCaseWeights, getManagedMemorySlotScopeUseCases, getMaxParallelism, getMinResources, getName, getNewNodeId, getOutputType, getParallelism, getPreferredResources, getSlotSharingGroup, getTransitivePredecessors, getUid, getUserProvidedNodeHash, hashCode, isParallelismConfigured, setAttribute, setBufferTimeout, setCoLocationGroupKey, setDescription, setMaxParallelism, setName, setOutputType, setParallelism, setParallelism, setResources, setSlotSharingGroup, setSlotSharingGroup, setUid, setUidHash, toString, updateManagedMemoryStateBackendUseCase
-
-
-
-
Constructor Detail
-
TimestampsAndWatermarksTransformation
public TimestampsAndWatermarksTransformation(String name, int parallelism, Transformation<IN> input, WatermarkStrategy<IN> watermarkStrategy, boolean parallelismConfigured)
Creates a newTransformation
with the given name, output type and parallelism.- Parameters:
name
- The name of theTransformation
, this will be shown in Visualizations and the Logparallelism
- The parallelism of thisTransformation
input
- The input transformation of thisTransformation
watermarkStrategy
- TheWatermarkStrategy
to use
-
-
Method Detail
-
getInputType
public TypeInformation<IN> getInputType()
Returns theTypeInformation
for the elements of the input.
-
getWatermarkStrategy
public WatermarkStrategy<IN> getWatermarkStrategy()
Returns theWatermarkStrategy
to use.
-
getTransitivePredecessorsInternal
protected List<Transformation<?>> getTransitivePredecessorsInternal()
Description copied from class:Transformation
Returns all transitive predecessorTransformation
s of thisTransformation
. This is, for example, used when determining whether a feedback edge of an iteration actually has the iteration head as a predecessor.- Specified by:
getTransitivePredecessorsInternal
in classTransformation<IN>
- Returns:
- The list of transitive predecessors.
-
getInputs
public List<Transformation<?>> getInputs()
Description copied from class:Transformation
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.- Specified by:
getInputs
in classTransformation<IN>
-
getChainingStrategy
public ChainingStrategy getChainingStrategy()
-
setChainingStrategy
public void setChainingStrategy(ChainingStrategy chainingStrategy)
Description copied from class:PhysicalTransformation
Sets the chaining strategy of thisTransformation
.- Specified by:
setChainingStrategy
in classPhysicalTransformation<IN>
-
-