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 classStateObjectCollection<T extends StateObject>This class represents a generic collection forStateObjects.Classes in org.apache.flink.runtime.checkpoint that implement StateObject 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.classStateObjectCollection<T extends StateObject>This class represents a generic collection forStateObjects.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.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 classChainedStateHandle<T extends StateObject>Handle to state handles for the operators in an operator chain.interfaceSnapshotable<S extends StateObject>Interface for objects that can snapshot its state (state backends currently).classSnapshotResult<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.interfaceSnapshotStrategy<S extends StateObject,SR extends SnapshotResources>Interface for different snapshot approaches in state backends.static interfaceSnapshotStrategy.SnapshotResultSupplier<S extends StateObject>A supplier for aSnapshotResultwith an access to aCloseableRegistryfor io tasks that need to be closed when cancelling the async part of the checkpoint.classSnapshotStrategyRunner<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 interfaceChannelStateempty interface just for mark a state object is unaligned checkpoint inflight-data.interfaceCheckpointBoundKeyedStateHandleKeyedStateHandlethat is bound to a specific checkpoint.interfaceCompositeStateHandleBase of all snapshots that are taken byStateBackends and some other components in tasks.interfaceIncrementalKeyedStateHandleCommon interface to all incrementalKeyedStateHandle.interfaceInputStateHandleempty interface just for mark a state object is input inflight-data.interfaceKeyedStateHandleBase for the handles of the checkpointed states in keyed streams.interfaceOperatorStateHandleInterface of a state handle for operator state.interfaceOutputStateHandleempty interface just for mark a state object is output inflight-data.interfaceRetrievableStateHandle<T extends Serializable>Handle to state that can be read back again viaRetrievableStateHandle.retrieveState().interfaceSavepointKeyedStateHandleAKeyedStateHandlethat points to a savepoint taken in the unified format.interfaceStreamStateHandleAStateObjectthat represents state that was written to a stream.Classes in org.apache.flink.runtime.state that implement StateObject Modifier and Type Class Description classAbstractChannelStateHandle<Info>Abstract channel state handle.classAbstractIncrementalStateHandleAbstract superclass for allIncrementalKeyedStateHandle.classAbstractMergedChannelStateHandle<Info,ChannelHandle extends AbstractChannelStateHandle<Info>>classChainedStateHandle<T extends StateObject>Handle to state handles for the operators in an operator chain.classDirectoryStateHandleThis state handle represents a directory.classIncrementalLocalKeyedStateHandleState handle for local copies ofIncrementalRemoteKeyedStateHandle.classIncrementalRemoteKeyedStateHandleThe handle to states of an incremental snapshot.classInputChannelStateHandleHandleto anInputChannelstate.classKeyGroupsSavepointStateHandleAKeyGroupsStateHandlethat describes a savepoint in the unified format.classKeyGroupsStateHandleA handle to the partitioned stream operator state after it has been checkpointed.classMergedInputChannelStateHandleclassMergedResultSubpartitionStateHandleclassOperatorStreamStateHandleState handle for partitionable operator state.classPlaceholderStreamStateHandleA placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.classResultSubpartitionStateHandleHandleto aResultSubpartitionstate.classRetrievableStreamStateHandle<T extends Serializable>Wrapper around aStreamStateHandleto make the referenced state object retrievable trough a simple get call.static classSharedStateRegistryImpl.EmptyDiscardStateObjectForRegisterAn object with empty discardState for registering.classSnapshotResult<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 voidStateUtil. discardStateObjectQuietly(StateObject stateObject)static longStateUtil. 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 voidStateUtil. 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 RuntimeExceptionStateUtil. unexpectedStateHandleException(Class<? extends StateObject> expectedStateHandleClass, Class<? extends StateObject> actualStateHandleClass)Creates anRuntimeExceptionthat signals that an operation did not get the type ofStateObjectthat 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 interfaceChangelogStateBackendHandleA handle to ChangelogStateBackend state.interfaceChangelogStateHandleA handle to savedstate changes.Classes in org.apache.flink.runtime.state.changelog that implement StateObject Modifier and Type Class Description static classChangelogStateBackendHandle.ChangelogStateBackendHandleImplclassChangelogStateBackendLocalHandleState handle for local copies ofChangelogStateHandleStreamImpl.classChangelogStateHandleStreamImplChangelogStateHandleimplementation 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 classInMemoryChangelogStateHandleIn-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 classDirectoryStreamStateHandleThis state handle represents a directory, usually used to be registered toSharedStateRegistryto track the life cycle of the directory.classEmptyFileMergingOperatorStreamStateHandleAn emptyFileMergingOperatorStreamStateHandlethat is only used as a placeholder to prevent file merging directory from being deleted.classEmptySegmentFileStateHandleAn emptySegmentFileStateHandlethat is only used as a placeholder.classFileMergingOperatorStreamStateHandleAOperatorStreamStateHandlethat works for file merging checkpoints.classSegmentFileStateHandleFileStateHandlefor 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 classFileStateHandleStreamStateHandlefor state that was written to a file stream.classRelativeFileStateHandleAStreamStateHandlefor 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 classByteStreamStateHandleA 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 passedStateObjectand 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 classBackendRestorerProcedure<T extends Closeable & org.apache.flink.util.Disposable,S extends StateObject>This class implements the logic that creates (and potentially restores) a state backend.
-