Uses of Interface
org.apache.flink.runtime.state.CompositeStateHandle
-
-
Uses of CompositeStateHandle in org.apache.flink.runtime.checkpoint
Classes in org.apache.flink.runtime.checkpoint that implement CompositeStateHandle Modifier and Type Class Description classFinishedOperatorSubtaskStateA specializedOperatorSubtaskStaterepresenting the subtask is finished.classFullyFinishedOperatorStateA special operator state implementation representing the operators whose instances are all finished.classOperatorStateSimple container class which contains the raw/managed operator state and key-group state handles from all subtasks of an operator and therefore represents the complete state of a logical operator.classOperatorSubtaskStateThis class encapsulates the state for one parallel instance of an operator.classSubtaskStateDeprecated.Internal class for savepoint backwards compatibility.classTaskStateDeprecated.Internal class for savepoint backwards compatibility.classTaskStateSnapshotThis class encapsulates state handles to the snapshots of all operator instances executed within one task. -
Uses of CompositeStateHandle in org.apache.flink.runtime.state
Subinterfaces of CompositeStateHandle in org.apache.flink.runtime.state Modifier and Type Interface Description interfaceCheckpointBoundKeyedStateHandleKeyedStateHandlethat is bound to a specific checkpoint.interfaceIncrementalKeyedStateHandleCommon interface to all incrementalKeyedStateHandle.interfaceKeyedStateHandleBase for the handles of the checkpointed states in keyed streams.interfaceSavepointKeyedStateHandleAKeyedStateHandlethat points to a savepoint taken in the unified format.Classes in org.apache.flink.runtime.state that implement CompositeStateHandle Modifier and Type Class Description classAbstractIncrementalStateHandleAbstract superclass for allIncrementalKeyedStateHandle.classIncrementalLocalKeyedStateHandleState handle for local copies ofIncrementalRemoteKeyedStateHandle.classIncrementalRemoteKeyedStateHandleThe handle to states of an incremental snapshot.classKeyGroupsSavepointStateHandleAKeyGroupsStateHandlethat describes a savepoint in the unified format.classKeyGroupsStateHandleA handle to the partitioned stream operator state after it has been checkpointed.Method parameters in org.apache.flink.runtime.state with type arguments of type CompositeStateHandle Modifier and Type Method Description voidSharedStateRegistry. registerAll(Iterable<? extends CompositeStateHandle> stateHandles, long checkpointID)Register given shared states in the registry.voidSharedStateRegistryImpl. registerAll(Iterable<? extends CompositeStateHandle> stateHandles, long checkpointID) -
Uses of CompositeStateHandle in org.apache.flink.runtime.state.changelog
Subinterfaces of CompositeStateHandle in org.apache.flink.runtime.state.changelog Modifier and Type Interface Description interfaceChangelogStateBackendHandleA handle to ChangelogStateBackend state.interfaceChangelogStateHandleA handle to savedstate changes.Classes in org.apache.flink.runtime.state.changelog that implement CompositeStateHandle Modifier and Type Class Description static classChangelogStateBackendHandle.ChangelogStateBackendHandleImplclassChangelogStateBackendLocalHandleState handle for local copies ofChangelogStateHandleStreamImpl.classChangelogStateHandleStreamImplChangelogStateHandleimplementation based onStreamStateHandle. -
Uses of CompositeStateHandle in org.apache.flink.runtime.state.changelog.inmemory
Classes in org.apache.flink.runtime.state.changelog.inmemory that implement CompositeStateHandle Modifier and Type Class Description classInMemoryChangelogStateHandleIn-memoryChangelogStateHandle. -
Uses of CompositeStateHandle in org.apache.flink.runtime.state.filemerging
Classes in org.apache.flink.runtime.state.filemerging that implement CompositeStateHandle Modifier and Type Class Description classEmptyFileMergingOperatorStreamStateHandleAn emptyFileMergingOperatorStreamStateHandlethat is only used as a placeholder to prevent file merging directory from being deleted.classFileMergingOperatorStreamStateHandleAOperatorStreamStateHandlethat works for file merging checkpoints.
-