Class SourceTransformation<OUT,SplitT extends SourceSplit,EnumChkT>
- java.lang.Object
-
- org.apache.flink.api.dag.Transformation<T>
-
- org.apache.flink.streaming.api.transformations.PhysicalTransformation<T>
-
- org.apache.flink.streaming.api.transformations.TransformationWithLineage<OUT>
-
- org.apache.flink.streaming.api.transformations.SourceTransformation<OUT,SplitT,EnumChkT>
-
- All Implemented Interfaces:
WithBoundedness
@Internal public class SourceTransformation<OUT,SplitT extends SourceSplit,EnumChkT> extends TransformationWithLineage<OUT> implements WithBoundedness
APhysicalTransformation
forSource
.
-
-
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 SourceTransformation(String name, Source<OUT,SplitT,EnumChkT> source, WatermarkStrategy<OUT> watermarkStrategy, TypeInformation<OUT> outputType, int parallelism)
Creates a newTransformation
with the given name, output type and parallelism.SourceTransformation(String name, Source<OUT,SplitT,EnumChkT> source, WatermarkStrategy<OUT> watermarkStrategy, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description Boundedness
getBoundedness()
Returns theBoundedness
of thisTransformation
.ChainingStrategy
getChainingStrategy()
String
getCoordinatorListeningID()
List<Transformation<?>>
getInputs()
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.Source<OUT,SplitT,EnumChkT>
getSource()
protected List<Transformation<?>>
getTransitivePredecessorsInternal()
Returns all transitive predecessorTransformation
s of thisTransformation
.WatermarkStrategy<OUT>
getWatermarkStrategy()
void
setChainingStrategy(ChainingStrategy chainingStrategy)
Sets the chaining strategy of thisTransformation
.void
setCoordinatorListeningID(String coordinatorListeningID)
-
Methods inherited from class org.apache.flink.streaming.api.transformations.TransformationWithLineage
getLineageVertex, setLineageVertex
-
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
-
SourceTransformation
public SourceTransformation(String name, Source<OUT,SplitT,EnumChkT> source, WatermarkStrategy<OUT> watermarkStrategy, TypeInformation<OUT> outputType, int parallelism)
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 Logsource
- TheSource
itselfwatermarkStrategy
- TheWatermarkStrategy
to useoutputType
- The output type of thisTransformation
parallelism
- The parallelism of thisTransformation
-
SourceTransformation
public SourceTransformation(String name, Source<OUT,SplitT,EnumChkT> source, WatermarkStrategy<OUT> watermarkStrategy, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
-
-
Method Detail
-
getWatermarkStrategy
public WatermarkStrategy<OUT> getWatermarkStrategy()
-
getBoundedness
public Boundedness getBoundedness()
Description copied from interface:WithBoundedness
Returns theBoundedness
of thisTransformation
.- Specified by:
getBoundedness
in interfaceWithBoundedness
-
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<OUT>
- 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<OUT>
-
setChainingStrategy
public void setChainingStrategy(ChainingStrategy chainingStrategy)
Description copied from class:PhysicalTransformation
Sets the chaining strategy of thisTransformation
.- Specified by:
setChainingStrategy
in classPhysicalTransformation<OUT>
-
getChainingStrategy
public ChainingStrategy getChainingStrategy()
-
setCoordinatorListeningID
public void setCoordinatorListeningID(@Nullable String coordinatorListeningID)
-
getCoordinatorListeningID
@Nullable public String getCoordinatorListeningID()
-
-