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 class
FinishedOperatorSubtaskState
A specializedOperatorSubtaskState
representing the subtask is finished.class
FullyFinishedOperatorState
A special operator state implementation representing the operators whose instances are all finished.class
OperatorState
Simple 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.class
OperatorSubtaskState
This class encapsulates the state for one parallel instance of an operator.class
SubtaskState
Deprecated.Internal class for savepoint backwards compatibility.class
TaskState
Deprecated.Internal class for savepoint backwards compatibility.class
TaskStateSnapshot
This 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 interface
CheckpointBoundKeyedStateHandle
KeyedStateHandle
that is bound to a specific checkpoint.interface
IncrementalKeyedStateHandle
Common interface to all incrementalKeyedStateHandle
.interface
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.interface
SavepointKeyedStateHandle
AKeyedStateHandle
that points to a savepoint taken in the unified format.Classes in org.apache.flink.runtime.state that implement CompositeStateHandle Modifier and Type Class Description class
AbstractIncrementalStateHandle
Abstract superclass for allIncrementalKeyedStateHandle
.class
IncrementalLocalKeyedStateHandle
State handle for local copies ofIncrementalRemoteKeyedStateHandle
.class
IncrementalRemoteKeyedStateHandle
The handle to states of an incremental snapshot.class
KeyGroupsSavepointStateHandle
AKeyGroupsStateHandle
that describes a savepoint in the unified format.class
KeyGroupsStateHandle
A 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 void
SharedStateRegistry. registerAll(Iterable<? extends CompositeStateHandle> stateHandles, long checkpointID)
Register given shared states in the registry.void
SharedStateRegistryImpl. 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 interface
ChangelogStateBackendHandle
A handle to ChangelogStateBackend state.interface
ChangelogStateHandle
A handle to savedstate changes
.Classes in org.apache.flink.runtime.state.changelog that implement CompositeStateHandle Modifier and Type Class Description static class
ChangelogStateBackendHandle.ChangelogStateBackendHandleImpl
class
ChangelogStateBackendLocalHandle
State handle for local copies ofChangelogStateHandleStreamImpl
.class
ChangelogStateHandleStreamImpl
ChangelogStateHandle
implementation 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 class
InMemoryChangelogStateHandle
In-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 class
EmptyFileMergingOperatorStreamStateHandle
An emptyFileMergingOperatorStreamStateHandle
that is only used as a placeholder to prevent file merging directory from being deleted.class
FileMergingOperatorStreamStateHandle
AOperatorStreamStateHandle
that works for file merging checkpoints.
-