Class PhysicalTransformation<T>
- java.lang.Object
-
- org.apache.flink.api.dag.Transformation<T>
-
- org.apache.flink.streaming.api.transformations.PhysicalTransformation<T>
-
- Type Parameters:
T
- The type of the elements that result from thisTransformation
- Direct Known Subclasses:
AbstractBroadcastStateTransformation
,AbstractMultipleInputTransformation
,DataStreamV2SinkTransformation
,OneInputTransformation
,ReduceTransformation
,TimestampsAndWatermarksTransformation
,TransformationWithLineage
,TwoInputTransformation
@Internal public abstract class PhysicalTransformation<T> extends Transformation<T>
ATransformation
that creates a physical operation. It enables settingChainingStrategy
.- See Also:
Transformation
-
-
Field Summary
-
Fields inherited from class org.apache.flink.api.dag.Transformation
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
-
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description boolean
isSupportsConcurrentExecutionAttempts()
abstract void
setChainingStrategy(ChainingStrategy strategy)
Sets the chaining strategy of thisTransformation
.void
setSupportsConcurrentExecutionAttempts(boolean supportsConcurrentExecutionAttempts)
-
Methods inherited from class org.apache.flink.api.dag.Transformation
declareManagedMemoryUseCaseAtOperatorScope, declareManagedMemoryUseCaseAtSlotScope, equals, getAttribute, getBufferTimeout, getCoLocationGroupKey, getDescription, getId, getInputs, getManagedMemoryOperatorScopeUseCaseWeights, getManagedMemorySlotScopeUseCases, getMaxParallelism, getMinResources, getName, getNewNodeId, getOutputType, getParallelism, getPreferredResources, getSlotSharingGroup, getTransitivePredecessors, getTransitivePredecessorsInternal, getUid, getUserProvidedNodeHash, hashCode, isParallelismConfigured, setAttribute, setBufferTimeout, setCoLocationGroupKey, setDescription, setMaxParallelism, setName, setOutputType, setParallelism, setParallelism, setResources, setSlotSharingGroup, setSlotSharingGroup, setUid, setUidHash, toString, updateManagedMemoryStateBackendUseCase
-
-
-
-
Method Detail
-
setChainingStrategy
public abstract void setChainingStrategy(ChainingStrategy strategy)
Sets the chaining strategy of thisTransformation
.
-
isSupportsConcurrentExecutionAttempts
public boolean isSupportsConcurrentExecutionAttempts()
-
setSupportsConcurrentExecutionAttempts
public void setSupportsConcurrentExecutionAttempts(boolean supportsConcurrentExecutionAttempts)
-
-