Uses of Class
org.apache.flink.runtime.state.InputChannelStateHandle
-
-
Uses of InputChannelStateHandle in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type InputChannelStateHandle Modifier and Type Method Description StateObjectCollection<InputChannelStateHandle>
OperatorSubtaskState. getInputChannelState()
StateObjectCollection<InputChannelStateHandle>
PrioritizedOperatorSubtaskState. getPrioritizedInputChannelState()
Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type InputChannelStateHandle Modifier and Type Method Description OperatorSubtaskState.Builder
OperatorSubtaskState.Builder. setInputChannelState(StateObjectCollection<InputChannelStateHandle> inputChannelState)
-
Uses of InputChannelStateHandle in org.apache.flink.runtime.checkpoint.channel
Methods in org.apache.flink.runtime.checkpoint.channel that return types with arguments of type InputChannelStateHandle Modifier and Type Method Description CompletableFuture<Collection<InputChannelStateHandle>>
ChannelStateWriter.ChannelStateWriteResult. getInputChannelStateHandles()
-
Uses of InputChannelStateHandle in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return types with arguments of type InputChannelStateHandle Modifier and Type Method Description protected StateObjectCollection<InputChannelStateHandle>
MetadataV2V3SerializerBase. deserializeInputChannelStateHandle(DataInputStream dis, MetadataV2V3SerializerBase.DeserializationContext context)
static StateObjectCollection<InputChannelStateHandle>
MetadataV3Serializer. deserializeInputChannelStateHandle(DataInputStream dis)
StateObjectCollection<InputChannelStateHandle>
MetadataV3Serializer. deserializeInputChannelStateHandle(DataInputStream dis, MetadataV2V3SerializerBase.DeserializationContext context)
Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type InputChannelStateHandle Modifier and Type Method Description protected void
MetadataV2V3SerializerBase. serializeInputChannelStateHandle(InputChannelStateHandle inputChannelStateHandle, DataOutputStream dos)
void
MetadataV3Serializer. serializeInputChannelStateHandle(InputChannelStateHandle handle, DataOutputStream dos)
-
Uses of InputChannelStateHandle in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type InputChannelStateHandle Modifier and Type Method Description Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>
OperatorSnapshotFutures. getInputChannelStateFuture()
Method parameters in org.apache.flink.streaming.api.operators with type arguments of type InputChannelStateHandle Modifier and Type Method Description void
OperatorSnapshotFutures. setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>> inputChannelStateFuture)
Constructor parameters in org.apache.flink.streaming.api.operators with type arguments of type InputChannelStateHandle Constructor Description OperatorSnapshotFutures(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture, RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture, RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture, Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>> inputChannelStateFuture, Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>> resultSubpartitionStateFuture)
-