Uses of Interface
org.apache.flink.runtime.state.StateObject
-
-
Uses of StateObject in org.apache.flink.runtime.checkpoint
Classes in org.apache.flink.runtime.checkpoint with type parameters of type StateObject Modifier and Type Class Description class
StateObjectCollection<T extends StateObject>
This class represents a generic collection forStateObject
s.Classes in org.apache.flink.runtime.checkpoint that implement StateObject 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
StateObjectCollection<T extends StateObject>
This class represents a generic collection forStateObject
s.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.Methods in org.apache.flink.runtime.checkpoint with type parameters of type StateObject Modifier and Type Method Description static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. empty()
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. emptyIfNull(StateObjectCollection<T> collection)
static <T extends StateObject>
voidStateAssignmentOperation. reDistributePartitionableStates(Map<OperatorID,OperatorState> oldOperatorStates, int newParallelism, Function<OperatorSubtaskState,StateObjectCollection<T>> extractHandle, OperatorStateRepartitioner<T> stateRepartitioner, Map<OperatorInstanceID,List<T>> result)
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. singleton(T stateObject)
static <T extends StateObject>
StateObjectCollection<T>StateObjectCollection. singletonOrEmpty(T stateObject)
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type StateObject Modifier and Type Method Description List<StateObject>
OperatorState. getDiscardables()
List<StateObject>
OperatorSubtaskState. getDiscardables()
-
Uses of StateObject in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state with type parameters of type StateObject Modifier and Type Class Description class
ChainedStateHandle<T extends StateObject>
Handle to state handles for the operators in an operator chain.interface
Snapshotable<S extends StateObject>
Interface for objects that can snapshot its state (state backends currently).class
SnapshotResult<T extends StateObject>
This class contains the combined results from the snapshot of a state backend: A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.interface
SnapshotStrategy<S extends StateObject,SR extends SnapshotResources>
Interface for different snapshot approaches in state backends.static interface
SnapshotStrategy.SnapshotResultSupplier<S extends StateObject>
A supplier for aSnapshotResult
with an access to aCloseableRegistry
for io tasks that need to be closed when cancelling the async part of the checkpoint.class
SnapshotStrategyRunner<T extends StateObject,SR extends SnapshotResources>
A class to execute aSnapshotStrategy
.Subinterfaces of StateObject in org.apache.flink.runtime.state Modifier and Type Interface Description interface
CheckpointBoundKeyedStateHandle
KeyedStateHandle
that is bound to a specific checkpoint.interface
CompositeStateHandle
Base of all snapshots that are taken byStateBackend
s and some other components in tasks.interface
IncrementalKeyedStateHandle
Common interface to all incrementalKeyedStateHandle
.interface
KeyedStateHandle
Base for the handles of the checkpointed states in keyed streams.interface
OperatorStateHandle
Interface of a state handle for operator state.interface
RetrievableStateHandle<T extends Serializable>
Handle to state that can be read back again viaRetrievableStateHandle.retrieveState()
.interface
SavepointKeyedStateHandle
AKeyedStateHandle
that points to a savepoint taken in the unified format.interface
StreamStateHandle
AStateObject
that represents state that was written to a stream.Classes in org.apache.flink.runtime.state that implement StateObject Modifier and Type Class Description class
AbstractChannelStateHandle<Info>
Abstract channel state handle.class
AbstractIncrementalStateHandle
Abstract superclass for allIncrementalKeyedStateHandle
.class
ChainedStateHandle<T extends StateObject>
Handle to state handles for the operators in an operator chain.class
DirectoryStateHandle
This state handle represents a directory.class
IncrementalLocalKeyedStateHandle
State handle for local copies ofIncrementalRemoteKeyedStateHandle
.class
IncrementalRemoteKeyedStateHandle
The handle to states of an incremental snapshot.class
InputChannelStateHandle
Handle
to anInputChannel
state.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.class
OperatorStreamStateHandle
State handle for partitionable operator state.class
PlaceholderStreamStateHandle
A placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.class
ResultSubpartitionStateHandle
Handle
to aResultSubpartition
state.class
RetrievableStreamStateHandle<T extends Serializable>
Wrapper around aStreamStateHandle
to make the referenced state object retrievable trough a simple get call.static class
SharedStateRegistryImpl.EmptyDiscardStateObjectForRegister
An object with empty discardState for registering.class
SnapshotResult<T extends StateObject>
This class contains the combined results from the snapshot of a state backend: A state object representing the state that will be reported to the Job Manager to acknowledge the checkpoint.Methods in org.apache.flink.runtime.state with type parameters of type StateObject Modifier and Type Method Description static <T extends StateObject>
SnapshotResult<T>SnapshotResult. empty()
static <T extends StateObject>
SnapshotResult<T>SnapshotResult. of(T jobManagerState)
static <T extends StateObject>
SnapshotResult<T>SnapshotResult. withLocalState(T jobManagerState, T localState)
static <T extends StateObject>
ChainedStateHandle<T>ChainedStateHandle. wrapSingleHandle(T stateHandleToWrap)
Methods in org.apache.flink.runtime.state with parameters of type StateObject Modifier and Type Method Description static void
StateUtil. discardStateObjectQuietly(StateObject stateObject)
static long
StateUtil. getStateSize(StateObject handle)
Returns the size of a state object.Method parameters in org.apache.flink.runtime.state with type arguments of type StateObject Modifier and Type Method Description static void
StateUtil. bestEffortDiscardAllStateObjects(Iterable<? extends StateObject> handlesToDiscard)
Iterates through the passed state handles and calls discardState() on each handle that is not null.static org.apache.flink.api.java.tuple.Tuple2<Long,Long>
StateUtil. discardStateFuture(Future<? extends StateObject> stateFuture)
Discards the given state future by first trying to cancel it.static RuntimeException
StateUtil. unexpectedStateHandleException(Class<? extends StateObject> expectedStateHandleClass, Class<? extends StateObject> actualStateHandleClass)
Creates anRuntimeException
that signals that an operation did not get the type ofStateObject
that was expected. -
Uses of StateObject in org.apache.flink.runtime.state.changelog
Subinterfaces of StateObject 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 StateObject 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 StateObject in org.apache.flink.runtime.state.changelog.inmemory
Classes in org.apache.flink.runtime.state.changelog.inmemory that implement StateObject Modifier and Type Class Description class
InMemoryChangelogStateHandle
In-memoryChangelogStateHandle
. -
Uses of StateObject in org.apache.flink.runtime.state.filemerging
Classes in org.apache.flink.runtime.state.filemerging that implement StateObject Modifier and Type Class Description class
DirectoryStreamStateHandle
This state handle represents a directory, usually used to be registered toSharedStateRegistry
to track the life cycle of the directory.class
EmptyFileMergingOperatorStreamStateHandle
An emptyFileMergingOperatorStreamStateHandle
that is only used as a placeholder to prevent file merging directory from being deleted.class
EmptySegmentFileStateHandle
An emptySegmentFileStateHandle
that is only used as a placeholder.class
FileMergingOperatorStreamStateHandle
AOperatorStreamStateHandle
that works for file merging checkpoints.class
SegmentFileStateHandle
FileStateHandle
for state that was written to a file segment. -
Uses of StateObject in org.apache.flink.runtime.state.filesystem
Classes in org.apache.flink.runtime.state.filesystem that implement StateObject Modifier and Type Class Description class
FileStateHandle
StreamStateHandle
for state that was written to a file stream.class
RelativeFileStateHandle
AStreamStateHandle
for state that was written to a file stream. -
Uses of StateObject in org.apache.flink.runtime.state.memory
Classes in org.apache.flink.runtime.state.memory that implement StateObject Modifier and Type Class Description class
ByteStreamStateHandle
A state handle that contains stream state in a byte array. -
Uses of StateObject in org.apache.flink.runtime.util
Methods in org.apache.flink.runtime.util with parameters of type StateObject Modifier and Type Method Description static byte[]
StateHandleStoreUtils. serializeOrDiscard(StateObject stateObject)
Serializes the passedStateObject
and discards the state in case of failure. -
Uses of StateObject in org.apache.flink.streaming.api.operators
Classes in org.apache.flink.streaming.api.operators with type parameters of type StateObject Modifier and Type Class Description class
BackendRestorerProcedure<T extends Closeable & org.apache.flink.util.Disposable,S extends StateObject>
This class implements the logic that creates (and potentially restores) a state backend.
-