Class KeyedMultipleInputTransformation<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.AbstractMultipleInputTransformation<OUT>
-
- org.apache.flink.streaming.api.transformations.KeyedMultipleInputTransformation<OUT>
-
@Internal public class KeyedMultipleInputTransformation<OUT> extends AbstractMultipleInputTransformation<OUT>
AbstractMultipleInputTransformation
implementation for keyed streams.
-
-
Field Summary
Fields Modifier and Type Field Description protected TypeInformation<?>
stateKeyType
-
Fields inherited from class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
inputs, operatorFactory
-
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 KeyedMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism, TypeInformation<?> stateKeyType)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description KeyedMultipleInputTransformation<OUT>
addInput(Transformation<?> input, KeySelector<?,?> keySelector)
List<KeySelector<?,?>>
getStateKeySelectors()
TypeInformation<?>
getStateKeyType()
-
Methods inherited from class org.apache.flink.streaming.api.transformations.AbstractMultipleInputTransformation
getInputs, getInputTypes, getOperatorFactory, getTransitivePredecessorsInternal, isInternalSorterSupported, isOutputOnlyAfterEndOfStream, 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
-
-
-
-
Field Detail
-
stateKeyType
protected final TypeInformation<?> stateKeyType
-
-
Constructor Detail
-
KeyedMultipleInputTransformation
public KeyedMultipleInputTransformation(String name, StreamOperatorFactory<OUT> operatorFactory, TypeInformation<OUT> outputType, int parallelism, TypeInformation<?> stateKeyType)
-
-
Method Detail
-
addInput
public KeyedMultipleInputTransformation<OUT> addInput(Transformation<?> input, KeySelector<?,?> keySelector)
-
getStateKeyType
public TypeInformation<?> getStateKeyType()
-
getStateKeySelectors
public List<KeySelector<?,?>> getStateKeySelectors()
-
-