T
- The type of the elements that this source produces@Internal public class LegacySourceTransformation<T> extends PhysicalTransformation<T> implements WithBoundedness
Transformation
of any topology.bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and Description |
---|
LegacySourceTransformation(String name,
StreamSource<T,?> operator,
TypeInformation<T> outputType,
int parallelism,
Boundedness boundedness,
boolean parallelismConfigured)
Creates a new
LegacySourceTransformation from the given operator. |
Modifier and Type | Method and Description |
---|---|
Boundedness |
getBoundedness()
Returns the
Boundedness of this Transformation . |
List<Transformation<?>> |
getInputs()
Returns the
transformations that are the immediate predecessors of the
current transformation in the transformation graph. |
StreamSource<T,?> |
getOperator() |
StreamOperatorFactory<T> |
getOperatorFactory()
Returns the
StreamOperatorFactory of this LegacySourceTransformation . |
protected List<Transformation<?>> |
getTransitivePredecessorsInternal()
Returns all transitive predecessor
Transformation s of this Transformation . |
void |
setBoundedness(Boundedness boundedness)
Mutable for legacy sources in the Table API.
|
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, getTransitivePredecessors, getUid, getUserProvidedNodeHash, hashCode, isParallelismConfigured, setBufferTimeout, setCoLocationGroupKey, setDescription, setMaxParallelism, setName, setOutputType, setParallelism, setParallelism, setResources, setSlotSharingGroup, setSlotSharingGroup, setUid, setUidHash, toString, updateManagedMemoryStateBackendUseCase
public LegacySourceTransformation(String name, StreamSource<T,?> operator, TypeInformation<T> outputType, int parallelism, Boundedness boundedness, boolean parallelismConfigured)
LegacySourceTransformation
from the given operator.name
- The name of the LegacySourceTransformation
, this will be shown in
Visualizations and the Logoperator
- The StreamSource
that is the operator of this TransformationoutputType
- The type of the elements produced by this LegacySourceTransformation
parallelism
- The parallelism of this LegacySourceTransformation
parallelismConfigured
- If true, the parallelism of the transformation is explicitly set
and should be respected. Otherwise the parallelism can be changed at runtime.public void setBoundedness(Boundedness boundedness)
public Boundedness getBoundedness()
WithBoundedness
Boundedness
of this Transformation
.getBoundedness
in interface WithBoundedness
@VisibleForTesting public StreamSource<T,?> getOperator()
public StreamOperatorFactory<T> getOperatorFactory()
StreamOperatorFactory
of this LegacySourceTransformation
.protected List<Transformation<?>> getTransitivePredecessorsInternal()
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.getTransitivePredecessorsInternal
in class Transformation<T>
public List<Transformation<?>> getInputs()
Transformation
transformations
that are the immediate predecessors of the
current transformation in the transformation graph.getInputs
in class Transformation<T>
public final void setChainingStrategy(ChainingStrategy strategy)
PhysicalTransformation
Transformation
.setChainingStrategy
in class PhysicalTransformation<T>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.