K
- type of the backend keys.public class RocksFullSnapshotStrategy<K> extends RocksDBSnapshotStrategyBase<K>
RocksDBKeyedStateBackend
. Iterates and writes all
states from a RocksDB snapshot of the column families.cancelStreamRegistry, db, keyGroupPrefixBytes, keyGroupRange, keySerializer, kvStateInformation, localRecoveryConfig, rocksDBResourceGuard
description
Constructor and Description |
---|
RocksFullSnapshotStrategy(org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
CloseableRegistry cancelStreamRegistry,
StreamCompressionDecorator keyGroupCompressionDecorator) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
doSnapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory primaryStreamFactory,
CheckpointOptions checkpointOptions)
This method implements the concrete snapshot logic for a non-empty state.
|
void |
notifyCheckpointAborted(long checkpointId)
This method is called as a notification once a distributed checkpoint has been aborted.
|
void |
notifyCheckpointComplete(long checkpointId)
This method is called as a notification once a distributed checkpoint has been completed.
|
snapshot
logAsyncCompleted, logSyncCompleted, toString
public RocksFullSnapshotStrategy(@Nonnull org.rocksdb.RocksDB db, @Nonnull ResourceGuard rocksDBResourceGuard, @Nonnull TypeSerializer<K> keySerializer, @Nonnull LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation, @Nonnull KeyGroupRange keyGroupRange, @Nonnegative int keyGroupPrefixBytes, @Nonnull LocalRecoveryConfig localRecoveryConfig, @Nonnull CloseableRegistry cancelStreamRegistry, @Nonnull StreamCompressionDecorator keyGroupCompressionDecorator)
@Nonnull public RunnableFuture<SnapshotResult<KeyedStateHandle>> doSnapshot(long checkpointId, long timestamp, @Nonnull CheckpointStreamFactory primaryStreamFactory, @Nonnull CheckpointOptions checkpointOptions) throws Exception
RocksDBSnapshotStrategyBase
doSnapshot
in class RocksDBSnapshotStrategyBase<K>
Exception
public void notifyCheckpointComplete(long checkpointId)
CheckpointListener
Note that any exception during this method will not cause the checkpoint to fail any more.
checkpointId
- The ID of the checkpoint that has been completed.public void notifyCheckpointAborted(long checkpointId)
CheckpointListener
checkpointId
- The ID of the checkpoint that has been aborted.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.