Uses of Interface
org.apache.flink.runtime.state.InputStateHandle
-
Packages that use InputStateHandle Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.checkpoint.metadata org.apache.flink.runtime.state org.apache.flink.streaming.api.operators -
-
Uses of InputStateHandle in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type InputStateHandle Modifier and Type Method Description StateObjectCollection<InputStateHandle>
OperatorSubtaskState. getInputChannelState()
StateObjectCollection<InputStateHandle>
PrioritizedOperatorSubtaskState. getPrioritizedInputChannelState()
Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type InputStateHandle Modifier and Type Method Description OperatorSubtaskState.Builder
OperatorSubtaskState.Builder. setInputChannelState(StateObjectCollection<InputStateHandle> inputChannelState)
-
Uses of InputStateHandle in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return types with arguments of type InputStateHandle Modifier and Type Method Description protected StateObjectCollection<InputStateHandle>
MetadataV2V3SerializerBase. deserializeInputStateHandle(DataInputStream dis, MetadataV2V3SerializerBase.DeserializationContext context)
StateObjectCollection<InputStateHandle>
MetadataV3Serializer. deserializeInputStateHandle(DataInputStream dis)
StateObjectCollection<InputStateHandle>
MetadataV3Serializer. deserializeInputStateHandle(DataInputStream dis, MetadataV2V3SerializerBase.DeserializationContext context)
Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type InputStateHandle Modifier and Type Method Description protected void
MetadataV2V3SerializerBase. serializeInputStateHandle(InputStateHandle handle, DataOutputStream dos)
void
MetadataV3Serializer. serializeInputStateHandle(InputStateHandle handle, DataOutputStream dos)
-
Uses of InputStateHandle in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement InputStateHandle Modifier and Type Class Description class
InputChannelStateHandle
Handle
to anInputChannel
state.class
MergedInputChannelStateHandle
Methods in org.apache.flink.runtime.state that return types with arguments of type InputStateHandle Modifier and Type Method Description static StateObjectCollection<InputStateHandle>
ChannelStateHelper. castToInputStateCollection(Collection<InputChannelStateHandle> handles)
static StateObjectCollection<InputStateHandle>
ChannelStateHelper. mergeInputStateCollection(Collection<InputChannelStateHandle> handles)
-
Uses of InputStateHandle in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type InputStateHandle Modifier and Type Method Description Future<SnapshotResult<StateObjectCollection<InputStateHandle>>>
OperatorSnapshotFutures. getInputChannelStateFuture()
Method parameters in org.apache.flink.streaming.api.operators with type arguments of type InputStateHandle Modifier and Type Method Description void
OperatorSnapshotFutures. setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputStateHandle>>> inputChannelStateFuture)
Constructor parameters in org.apache.flink.streaming.api.operators with type arguments of type InputStateHandle Constructor Description OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture, RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture, Future<SnapshotResult<StateObjectCollection<InputStateHandle>>> inputChannelStateFuture, Future<SnapshotResult<StateObjectCollection<OutputStateHandle>>> resultSubpartitionStateFuture)
-