T
- The type of the elements in the input LegacySinkTransformation
@Internal public class LegacySinkTransformation<T> extends PhysicalTransformation<T>
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and Description |
---|
LegacySinkTransformation(Transformation<T> input,
String name,
StreamOperatorFactory<Object> operatorFactory,
int parallelism) |
LegacySinkTransformation(Transformation<T> input,
String name,
StreamOperatorFactory<Object> operatorFactory,
int parallelism,
boolean parallelismConfigured) |
LegacySinkTransformation(Transformation<T> input,
String name,
StreamSink<T> operator,
int parallelism,
boolean parallelismConfigured)
Creates a new
LegacySinkTransformation from the given input Transformation . |
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. |
StreamSink<T> |
getOperator() |
StreamOperatorFactory<Object> |
getOperatorFactory()
Returns the
StreamOperatorFactory of this LegacySinkTransformation . |
KeySelector<T,?> |
getStateKeySelector()
Returns the
KeySelector that must be used for partitioning keyed state in this Sink. |
TypeInformation<?> |
getStateKeyType() |
List<Transformation<?>> |
getTransitivePredecessors()
Returns all transitive predecessor
Transformation s of this Transformation . |
boolean |
isSupportsConcurrentExecutionAttempts() |
void |
setChainingStrategy(ChainingStrategy strategy)
Sets the chaining strategy of this
Transformation . |
void |
setStateKeySelector(KeySelector<T,?> stateKeySelector)
Sets the
KeySelector that must be used for partitioning keyed state of this Sink. |
void |
setStateKeyType(TypeInformation<?> stateKeyType) |
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
public LegacySinkTransformation(Transformation<T> input, String name, StreamSink<T> operator, int parallelism, boolean parallelismConfigured)
LegacySinkTransformation
from the given input Transformation
.input
- The input Transformation
name
- The name of the Transformation
, this will be shown in Visualizations and
the Logoperator
- The sink operatorparallelism
- The parallelism of this LegacySinkTransformation
parallelismConfigured
- If true, the parallelism of the transformation is explicitly set
and should be respected. Otherwise the parallelism can be changed at runtime.public LegacySinkTransformation(Transformation<T> input, String name, StreamOperatorFactory<Object> operatorFactory, int parallelism)
public LegacySinkTransformation(Transformation<T> input, String name, StreamOperatorFactory<Object> operatorFactory, int parallelism, boolean parallelismConfigured)
@VisibleForTesting public StreamSink<T> getOperator()
public StreamOperatorFactory<Object> getOperatorFactory()
StreamOperatorFactory
of this LegacySinkTransformation
.public void setStateKeySelector(KeySelector<T,?> stateKeySelector)
KeySelector
that must be used for partitioning keyed state of this Sink.stateKeySelector
- The KeySelector
to setpublic KeySelector<T,?> getStateKeySelector()
KeySelector
that must be used for partitioning keyed state in this Sink.public void setStateKeyType(TypeInformation<?> stateKeyType)
public TypeInformation<?> getStateKeyType()
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<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>
public boolean isSupportsConcurrentExecutionAttempts()
isSupportsConcurrentExecutionAttempts
in class PhysicalTransformation<T>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.