Class AbstractMultipleInputTransformation<OUT>
- java.lang.Object
-
- org.apache.flink.api.dag.Transformation<T>
-
- org.apache.flink.streaming.api.transformations.PhysicalTransformation<OUT>
-
- org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation<OUT>
-
- Type Parameters:
OUT
- The type of the elements that result from thisMultipleInputTransformation
- Direct Known Subclasses:
KeyedMultipleInputTransformation
,MultipleInputTransformation
@Internal public abstract class AbstractMultipleInputTransformation<OUT> extends PhysicalTransformation<OUT>
Base class for transformations representing the application of aMultipleInputStreamOperator
to inputTransformations
. The result is again only one stream.
-
-
Field Summary
Fields Modifier and Type Field Description protected List<Transformation<?>>
inputs
protected StreamOperatorFactory<OUT>
operatorFactory
-
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 AbstractMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism)
AbstractMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description List<Transformation<?>>
getInputs()
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.List<TypeInformation<?>>
getInputTypes()
Returns theTypeInformation
for the elements from the inputs.StreamOperatorFactory<OUT>
getOperatorFactory()
Returns theStreamOperatorFactory
of this Transformation.protected List<Transformation<?>>
getTransitivePredecessorsInternal()
Returns all transitive predecessorTransformation
s of thisTransformation
.boolean
isInternalSorterSupported()
boolean
isOutputOnlyAfterEndOfStream()
void
setChainingStrategy(ChainingStrategy strategy)
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
-
-
-
-
Field Detail
-
inputs
protected final List<Transformation<?>> inputs
-
operatorFactory
protected final StreamOperatorFactory<OUT> operatorFactory
-
-
Constructor Detail
-
AbstractMultipleInputTransformation
public AbstractMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism)
-
AbstractMultipleInputTransformation
public AbstractMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
-
-
Method Detail
-
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>
-
getInputTypes
public List<TypeInformation<?>> getInputTypes()
Returns theTypeInformation
for the elements from the inputs.
-
getOperatorFactory
public StreamOperatorFactory<OUT> getOperatorFactory()
Returns theStreamOperatorFactory
of this Transformation.
-
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.
-
setChainingStrategy
public final void setChainingStrategy(ChainingStrategy strategy)
Description copied from class:PhysicalTransformation
Sets the chaining strategy of thisTransformation
.- Specified by:
setChainingStrategy
in classPhysicalTransformation<OUT>
-
isOutputOnlyAfterEndOfStream
public boolean isOutputOnlyAfterEndOfStream()
-
isInternalSorterSupported
public boolean isInternalSorterSupported()
-
-