Package org.apache.flink.runtime.state
Class NoOpTaskLocalStateStoreImpl
- java.lang.Object
-
- org.apache.flink.runtime.state.NoOpTaskLocalStateStoreImpl
-
- All Implemented Interfaces:
OwnedTaskLocalStateStore,TaskLocalStateStore
public final class NoOpTaskLocalStateStoreImpl extends Object implements OwnedTaskLocalStateStore
This class implements aTaskLocalStateStorewith no functionality and is used when local recovery is disabled.
-
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidabortCheckpoint(long abortedCheckpointId)Notifies that the checkpoint with the given id was confirmed as aborted.voidconfirmCheckpoint(long confirmedCheckpointId)Notifies that the checkpoint with the given id was confirmed as complete.CompletableFuture<Void>dispose()Disposes the task local state store.LocalRecoveryConfiggetLocalRecoveryConfig()Returns theLocalRecoveryConfigfor this task local state store.voidpruneMatchingCheckpoints(LongPredicate matcher)Remove all checkpoints from the store that match the given predicate.TaskStateSnapshotretrieveLocalState(long checkpointID)Returns the local state that is stored under the given checkpoint id or null if nothing was stored under the id.voidstoreLocalState(long checkpointId, TaskStateSnapshot localState)Stores the local state for the given checkpoint id.
-
-
-
Method Detail
-
getLocalRecoveryConfig
@Nonnull public LocalRecoveryConfig getLocalRecoveryConfig()
Description copied from interface:TaskLocalStateStoreReturns theLocalRecoveryConfigfor this task local state store.- Specified by:
getLocalRecoveryConfigin interfaceTaskLocalStateStore
-
dispose
public CompletableFuture<Void> dispose()
Description copied from interface:OwnedTaskLocalStateStoreDisposes the task local state store. Disposal can happen asynchronously and completion is signaled through the returned future.- Specified by:
disposein interfaceOwnedTaskLocalStateStore
-
storeLocalState
public void storeLocalState(long checkpointId, @Nullable TaskStateSnapshot localState)Description copied from interface:TaskLocalStateStoreStores the local state for the given checkpoint id.- Specified by:
storeLocalStatein interfaceTaskLocalStateStore- Parameters:
checkpointId- id for the checkpoint that created the local state that will be stored.localState- the local state to store.
-
retrieveLocalState
@Nullable public TaskStateSnapshot retrieveLocalState(long checkpointID)
Description copied from interface:TaskLocalStateStoreReturns the local state that is stored under the given checkpoint id or null if nothing was stored under the id.- Specified by:
retrieveLocalStatein interfaceTaskLocalStateStore- Parameters:
checkpointID- the checkpoint id by which we search for local state.- Returns:
- the local state found for the given checkpoint id. Can be null
-
confirmCheckpoint
public void confirmCheckpoint(long confirmedCheckpointId)
Description copied from interface:TaskLocalStateStoreNotifies that the checkpoint with the given id was confirmed as complete. This prunes the checkpoint history and removes all local states with a checkpoint id that is smaller than the newly confirmed checkpoint id.- Specified by:
confirmCheckpointin interfaceTaskLocalStateStore
-
abortCheckpoint
public void abortCheckpoint(long abortedCheckpointId)
Description copied from interface:TaskLocalStateStoreNotifies that the checkpoint with the given id was confirmed as aborted. This prunes the checkpoint history and removes states with a checkpoint id that is equal to the newly aborted checkpoint id.- Specified by:
abortCheckpointin interfaceTaskLocalStateStore
-
pruneMatchingCheckpoints
public void pruneMatchingCheckpoints(LongPredicate matcher)
Description copied from interface:TaskLocalStateStoreRemove all checkpoints from the store that match the given predicate.- Specified by:
pruneMatchingCheckpointsin interfaceTaskLocalStateStore- Parameters:
matcher- the predicate that selects the checkpoints for pruning.
-
-