InputT
- The input type of the SinkWriter
OutputT
- The output type of the Sink
@Internal public class DataStreamV2SinkTransformation<InputT,OutputT> extends PhysicalTransformation<OutputT>
Transformation
for DataStream V2 based sink.bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and Description |
---|
DataStreamV2SinkTransformation(AbstractDataStream<InputT> inputStream,
Sink<InputT> sink,
TypeInformation<OutputT> outputType,
String name,
int parallelism,
boolean parallelismConfigured) |
Modifier and Type | Method and Description |
---|---|
ChainingStrategy |
getChainingStrategy() |
List<Transformation<?>> |
getInputs()
Returns the
transformations that are the immediate predecessors of the
current transformation in the transformation graph. |
AbstractDataStream<InputT> |
getInputStream() |
Sink<InputT> |
getSink() |
protected List<Transformation<?>> |
getTransitivePredecessorsInternal()
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, 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
public DataStreamV2SinkTransformation(AbstractDataStream<InputT> inputStream, Sink<InputT> sink, TypeInformation<OutputT> outputType, String name, int parallelism, boolean parallelismConfigured)
public void setChainingStrategy(ChainingStrategy strategy)
PhysicalTransformation
Transformation
.setChainingStrategy
in class PhysicalTransformation<OutputT>
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<OutputT>
public List<Transformation<?>> getInputs()
Transformation
transformations
that are the immediate predecessors of the
current transformation in the transformation graph.getInputs
in class Transformation<OutputT>
@Nullable public ChainingStrategy getChainingStrategy()
public AbstractDataStream<InputT> getInputStream()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.