OUT
- The type of the elements that result from this MultipleInputTransformation
@Internal public abstract class AbstractMultipleInputTransformation<OUT> extends PhysicalTransformation<OUT>
MultipleInputStreamOperator
to input Transformations
. The result is again only one stream.Modifier and Type | Field and Description |
---|---|
protected List<Transformation<?>> |
inputs |
protected StreamOperatorFactory<OUT> |
operatorFactory |
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
List<Transformation<?>> |
getInputs()
Returns the
transformations that are the immediate predecessors of the
current transformation in the transformation graph. |
List<TypeInformation<?>> |
getInputTypes()
Returns the
TypeInformation for the elements from the inputs. |
StreamOperatorFactory<OUT> |
getOperatorFactory()
Returns the
StreamOperatorFactory of this Transformation. |
List<Transformation<?>> |
getTransitivePredecessors()
Returns all transitive predecessor
Transformation s of this Transformation . |
void |
setChainingStrategy(ChainingStrategy strategy)
Sets the chaining strategy of this
Transformation . |
isSupportsConcurrentExecutionAttempts, setSupportsConcurrentExecutionAttempts
declareManagedMemoryUseCaseAtOperatorScope, declareManagedMemoryUseCaseAtSlotScope, equals, getBufferTimeout, getCoLocationGroupKey, getDescription, getId, getManagedMemoryOperatorScopeUseCaseWeights, getManagedMemorySlotScopeUseCases, getMaxParallelism, getMinResources, getName, getNewNodeId, getOutputType, getParallelism, getPreferredResources, getSlotSharingGroup, getUid, getUserProvidedNodeHash, hashCode, isParallelismConfigured, setBufferTimeout, setCoLocationGroupKey, setDescription, setMaxParallelism, setName, setOutputType, setParallelism, setParallelism, setResources, setSlotSharingGroup, setSlotSharingGroup, setUid, setUidHash, toString, updateManagedMemoryStateBackendUseCase
protected final List<Transformation<?>> inputs
protected final StreamOperatorFactory<OUT> operatorFactory
public AbstractMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism)
public AbstractMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
public List<Transformation<?>> getInputs()
Transformation
transformations
that are the immediate predecessors of the
current transformation in the transformation graph.getInputs
in class Transformation<OUT>
public List<TypeInformation<?>> getInputTypes()
TypeInformation
for the elements from the inputs.public StreamOperatorFactory<OUT> getOperatorFactory()
StreamOperatorFactory
of this Transformation.public List<Transformation<?>> getTransitivePredecessors()
Transformation
Transformation
s of this Transformation
.
This is, for example, used when determining whether a feedback edge of an iteration actually
has the iteration head as a predecessor.getTransitivePredecessors
in class Transformation<OUT>
public final void setChainingStrategy(ChainingStrategy strategy)
PhysicalTransformation
Transformation
.setChainingStrategy
in class PhysicalTransformation<OUT>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.