Uses of Interface
org.apache.flink.runtime.state.OutputStateHandle
-
Packages that use OutputStateHandle 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 OutputStateHandle in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type OutputStateHandle Modifier and Type Method Description StateObjectCollection<OutputStateHandle>PrioritizedOperatorSubtaskState. getPrioritizedResultSubpartitionState()StateObjectCollection<OutputStateHandle>OperatorSubtaskState. getResultSubpartitionState()Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type OutputStateHandle Modifier and Type Method Description OperatorSubtaskState.BuilderOperatorSubtaskState.Builder. setResultSubpartitionState(StateObjectCollection<OutputStateHandle> resultSubpartitionState) -
Uses of OutputStateHandle in org.apache.flink.runtime.checkpoint.metadata
Methods in org.apache.flink.runtime.checkpoint.metadata that return types with arguments of type OutputStateHandle Modifier and Type Method Description protected StateObjectCollection<OutputStateHandle>MetadataV2V3SerializerBase. deserializeOutputStateHandle(DataInputStream dis, MetadataV2V3SerializerBase.DeserializationContext context)StateObjectCollection<OutputStateHandle>MetadataV3Serializer. deserializeOutputStateHandle(DataInputStream dis)StateObjectCollection<OutputStateHandle>MetadataV3Serializer. deserializeOutputStateHandle(DataInputStream dis, MetadataV2V3SerializerBase.DeserializationContext context)Methods in org.apache.flink.runtime.checkpoint.metadata with parameters of type OutputStateHandle Modifier and Type Method Description protected voidMetadataV2V3SerializerBase. serializeOutputStateHandle(OutputStateHandle handle, DataOutputStream dos)voidMetadataV3Serializer. serializeOutputStateHandle(OutputStateHandle handle, DataOutputStream dos) -
Uses of OutputStateHandle in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement OutputStateHandle Modifier and Type Class Description classMergedResultSubpartitionStateHandleclassResultSubpartitionStateHandleHandleto aResultSubpartitionstate.Methods in org.apache.flink.runtime.state that return types with arguments of type OutputStateHandle Modifier and Type Method Description static StateObjectCollection<OutputStateHandle>ChannelStateHelper. castToOutputStateCollection(Collection<ResultSubpartitionStateHandle> handles)static StateObjectCollection<OutputStateHandle>ChannelStateHelper. mergeOutputStateCollection(Collection<ResultSubpartitionStateHandle> handles) -
Uses of OutputStateHandle in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type OutputStateHandle Modifier and Type Method Description Future<SnapshotResult<StateObjectCollection<OutputStateHandle>>>OperatorSnapshotFutures. getResultSubpartitionStateFuture()Method parameters in org.apache.flink.streaming.api.operators with type arguments of type OutputStateHandle Modifier and Type Method Description voidOperatorSnapshotFutures. setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<OutputStateHandle>>> resultSubpartitionStateFuture)
-