@Internal public class PythonBroadcastStateTransformation<IN1,IN2,OUT> extends AbstractBroadcastStateTransformation<IN1,IN2,OUT> implements DelegateOperatorTransformation<OUT>
Transformation
representing a Python Co-Broadcast-Process operation, which will be
translated into different operations by PythonBroadcastStateTransformationTranslator
.DelegateOperatorTransformation.DelegateOperator<OUT>
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and Description |
---|
PythonBroadcastStateTransformation(String name,
Configuration configuration,
DataStreamPythonFunctionInfo dataStreamPythonFunctionInfo,
Transformation<IN1> regularInput,
Transformation<IN2> broadcastInput,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
Configuration |
getConfiguration() |
DataStreamPythonFunctionInfo |
getDataStreamPythonFunctionInfo() |
SimpleOperatorFactory<OUT> |
getOperatorFactory() |
getBroadcastInput, getBroadcastStateDescriptors, getChainingStrategy, getInputs, getRegularInput, getTransitivePredecessors, setChainingStrategy
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
clone, finalize, getClass, notify, notifyAll, wait, wait, wait
configureOperator
public PythonBroadcastStateTransformation(String name, Configuration configuration, DataStreamPythonFunctionInfo dataStreamPythonFunctionInfo, Transformation<IN1> regularInput, Transformation<IN2> broadcastInput, List<MapStateDescriptor<?,?>> broadcastStateDescriptors, TypeInformation<OUT> outTypeInfo, int parallelism)
public Configuration getConfiguration()
public DataStreamPythonFunctionInfo getDataStreamPythonFunctionInfo()
public SimpleOperatorFactory<OUT> getOperatorFactory()
getOperatorFactory
in interface DelegateOperatorTransformation<OUT>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.