K
- type of the backend keys.public class RocksIncrementalSnapshotStrategy<K> extends RocksDBSnapshotStrategyBase<K>
RocksDBKeyedStateBackend
that is based
on RocksDB's native checkpoints and creates incremental snapshots.cancelStreamRegistry, db, keyGroupPrefixBytes, keyGroupRange, keySerializer, kvStateInformation, localRecoveryConfig, rocksDBResourceGuard
description
Constructor and Description |
---|
RocksIncrementalSnapshotStrategy(org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
CloseableRegistry cancelStreamRegistry,
File instanceBasePath,
UUID backendUID,
SortedMap<Long,Set<StateHandleID>> materializedSstFiles,
long lastCompletedCheckpointId,
int numberOfTransferingThreads) |
Modifier and Type | Method and Description |
---|---|
protected RunnableFuture<SnapshotResult<KeyedStateHandle>> |
doSnapshot(long checkpointId,
long checkpointTimestamp,
CheckpointStreamFactory checkpointStreamFactory,
CheckpointOptions checkpointOptions)
This method implements the concrete snapshot logic for a non-empty state.
|
void |
notifyCheckpointComplete(long completedCheckpointId)
This method is called as a notification once a distributed checkpoint has been completed.
|
snapshot
logAsyncCompleted, logSyncCompleted, toString
public RocksIncrementalSnapshotStrategy(@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 File instanceBasePath, @Nonnull UUID backendUID, @Nonnull SortedMap<Long,Set<StateHandleID>> materializedSstFiles, long lastCompletedCheckpointId, int numberOfTransferingThreads)
@Nonnull protected RunnableFuture<SnapshotResult<KeyedStateHandle>> doSnapshot(long checkpointId, long checkpointTimestamp, @Nonnull CheckpointStreamFactory checkpointStreamFactory, @Nonnull CheckpointOptions checkpointOptions) throws Exception
RocksDBSnapshotStrategyBase
doSnapshot
in class RocksDBSnapshotStrategyBase<K>
Exception
public void notifyCheckpointComplete(long completedCheckpointId)
CheckpointListener
completedCheckpointId
- The ID of the checkpoint that has been completed.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.