Class AbstractBroadcastStateTransformation<IN1,IN2,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<IN1,IN2,OUT>
-
- Type Parameters:
IN1
- The type of the elements in the non-broadcasted input.IN2
- The type of the elements in the broadcasted input.OUT
- The type of the elements that result from this transformation.
- Direct Known Subclasses:
BroadcastStateTransformation
,KeyedBroadcastStateTransformation
,PythonBroadcastStateTransformation
,PythonKeyedBroadcastStateTransformation
@Internal public class AbstractBroadcastStateTransformation<IN1,IN2,OUT> extends PhysicalTransformation<OUT>
Base class for Broadcast State transformations. In a nutshell, this transformation allows to take a broadcast (non-keyed) stream, connect it with another keyed or non-keyed stream, and apply a function on the resulting connected stream.For more information see the Broadcast State Pattern documentation page.
-
-
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 Modifier Constructor Description protected
AbstractBroadcastStateTransformation(String name, Transformation<IN1> regularInput, Transformation<IN2> broadcastInput, List<MapStateDescriptor<?,?>> broadcastStateDescriptors, TypeInformation<OUT> outTypeInfo, int parallelism)
protected
AbstractBroadcastStateTransformation(String name, Transformation<IN1> regularInput, Transformation<IN2> broadcastInput, List<MapStateDescriptor<?,?>> broadcastStateDescriptors, TypeInformation<OUT> outTypeInfo, int parallelism, boolean parallelismConfigured)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description Transformation<IN2>
getBroadcastInput()
List<MapStateDescriptor<?,?>>
getBroadcastStateDescriptors()
ChainingStrategy
getChainingStrategy()
List<Transformation<?>>
getInputs()
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.Transformation<IN1>
getRegularInput()
protected List<Transformation<?>>
getTransitivePredecessorsInternal()
Returns all transitive predecessorTransformation
s of thisTransformation
.void
setChainingStrategy(ChainingStrategy chainingStrategy)
Sets the chaining strategy of thisTransformation
.-
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
-
AbstractBroadcastStateTransformation
protected AbstractBroadcastStateTransformation(String name, Transformation<IN1> regularInput, Transformation<IN2> broadcastInput, List<MapStateDescriptor<?,?>> broadcastStateDescriptors, TypeInformation<OUT> outTypeInfo, int parallelism)
-
AbstractBroadcastStateTransformation
protected AbstractBroadcastStateTransformation(String name, Transformation<IN1> regularInput, Transformation<IN2> broadcastInput, List<MapStateDescriptor<?,?>> broadcastStateDescriptors, TypeInformation<OUT> outTypeInfo, int parallelism, boolean parallelismConfigured)
-
-
Method Detail
-
getBroadcastInput
public Transformation<IN2> getBroadcastInput()
-
getRegularInput
public Transformation<IN1> getRegularInput()
-
getBroadcastStateDescriptors
public List<MapStateDescriptor<?,?>> getBroadcastStateDescriptors()
-
getChainingStrategy
public ChainingStrategy getChainingStrategy()
-
setChainingStrategy
public void setChainingStrategy(ChainingStrategy chainingStrategy)
Description copied from class:PhysicalTransformation
Sets the chaining strategy of thisTransformation
.- Specified by:
setChainingStrategy
in classPhysicalTransformation<OUT>
-
getTransitivePredecessorsInternal
protected List<Transformation<?>> getTransitivePredecessorsInternal()
Description copied from class:Transformation
Returns all transitive predecessorTransformation
s of thisTransformation
. This is, for example, used when determining whether a feedback edge of an iteration actually has the iteration head as a predecessor.- Specified by:
getTransitivePredecessorsInternal
in classTransformation<OUT>
- Returns:
- The list of transitive predecessors.
-
getInputs
public List<Transformation<?>> getInputs()
Description copied from class:Transformation
Returns thetransformations
that are the immediate predecessors of the current transformation in the transformation graph.- Specified by:
getInputs
in classTransformation<OUT>
-
-