@Internal public class PythonKeyedBroadcastStateTransformation<OUT> extends AbstractBroadcastStateTransformation<Row,Row,OUT> implements DelegateOperatorTransformation<OUT>
Transformation
representing a Python Keyed-Co-Broadcast-Process operation, which will
be translated into different operations by PythonKeyedBroadcastStateTransformationTranslator
.DelegateOperatorTransformation.DelegateOperator<OUT>
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
Constructor and Description |
---|
PythonKeyedBroadcastStateTransformation(String name,
Configuration configuration,
DataStreamPythonFunctionInfo dataStreamPythonFunctionInfo,
Transformation<Row> regularInput,
Transformation<Row> broadcastInput,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<Row> keyType,
KeySelector<Row,Row> keySelector,
TypeInformation<OUT> outTypeInfo,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
Configuration |
getConfiguration() |
DataStreamPythonFunctionInfo |
getDataStreamPythonFunctionInfo() |
KeySelector<Row,Row> |
getKeySelector() |
SimpleOperatorFactory<OUT> |
getOperatorFactory() |
TypeInformation<Row> |
getStateKeyType() |
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 PythonKeyedBroadcastStateTransformation(String name, Configuration configuration, DataStreamPythonFunctionInfo dataStreamPythonFunctionInfo, Transformation<Row> regularInput, Transformation<Row> broadcastInput, List<MapStateDescriptor<?,?>> broadcastStateDescriptors, TypeInformation<Row> keyType, KeySelector<Row,Row> keySelector, TypeInformation<OUT> outTypeInfo, int parallelism)
public Configuration getConfiguration()
public DataStreamPythonFunctionInfo getDataStreamPythonFunctionInfo()
public TypeInformation<Row> getStateKeyType()
public KeySelector<Row,Row> getKeySelector()
public SimpleOperatorFactory<OUT> getOperatorFactory()
getOperatorFactory
in interface DelegateOperatorTransformation<OUT>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.