Class PythonKeyedBroadcastStateTransformation<OUT>
- java.lang.Object
-
- org.apache.flink.api.dag.Transformation<T>
-
- org.apache.flink.streaming.api.transformations.PhysicalTransformation<OUT>
-
- org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation<Row,Row,OUT>
-
- org.apache.flink.streaming.api.transformations.python.PythonKeyedBroadcastStateTransformation<OUT>
-
- All Implemented Interfaces:
DelegateOperatorTransformation<OUT>
@Internal public class PythonKeyedBroadcastStateTransformation<OUT> extends AbstractBroadcastStateTransformation<Row,Row,OUT> implements DelegateOperatorTransformation<OUT>
ATransformation
representing a Python Keyed-Co-Broadcast-Process operation, which will be translated into different operations byPythonKeyedBroadcastStateTransformationTranslator
.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.streaming.api.transformations.python.DelegateOperatorTransformation
DelegateOperatorTransformation.DelegateOperator<OUT>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.api.dag.Transformation
bufferTimeout, description, id, name, outputType, typeUsed, UPPER_BOUND_MAX_PARALLELISM
-
-
Constructor Summary
Constructors Constructor 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)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description Configuration
getConfiguration()
DataStreamPythonFunctionInfo
getDataStreamPythonFunctionInfo()
KeySelector<Row,Row>
getKeySelector()
SimpleOperatorFactory<OUT>
getOperatorFactory()
TypeInformation<Row>
getStateKeyType()
-
Methods inherited from class org.apache.flink.streaming.api.transformations.AbstractBroadcastStateTransformation
getBroadcastInput, getBroadcastStateDescriptors, getChainingStrategy, getInputs, getRegularInput, getTransitivePredecessorsInternal, setChainingStrategy
-
Methods inherited from class org.apache.flink.streaming.api.transformations.PhysicalTransformation
isSupportsConcurrentExecutionAttempts, setSupportsConcurrentExecutionAttempts
-
Methods inherited from class org.apache.flink.api.dag.Transformation
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
-
-
-
-
Constructor Detail
-
PythonKeyedBroadcastStateTransformation
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)
-
-
Method Detail
-
getConfiguration
public Configuration getConfiguration()
-
getDataStreamPythonFunctionInfo
public DataStreamPythonFunctionInfo getDataStreamPythonFunctionInfo()
-
getStateKeyType
public TypeInformation<Row> getStateKeyType()
-
getKeySelector
public KeySelector<Row,Row> getKeySelector()
-
getOperatorFactory
public SimpleOperatorFactory<OUT> getOperatorFactory()
- Specified by:
getOperatorFactory
in interfaceDelegateOperatorTransformation<OUT>
-
-