public class RocksDBFullSnapshotResources<K> extends Object implements FullSnapshotResources<K>
FullSnapshotResources
for the RocksDB backend.Constructor and Description |
---|
RocksDBFullSnapshotResources(ResourceGuard.Lease lease,
org.rocksdb.Snapshot snapshot,
List<RocksDBKeyedStateBackend.RocksDbKvStateInfo> metaDataCopy,
List<HeapPriorityQueueStateSnapshot<?>> heapPriorityQueuesSnapshots,
List<StateMetaInfoSnapshot> stateMetaInfoSnapshots,
org.rocksdb.RocksDB db,
int keyGroupPrefixBytes,
KeyGroupRange keyGroupRange,
TypeSerializer<K> keySerializer,
StreamCompressionDecorator streamCompressionDecorator) |
Modifier and Type | Method and Description |
---|---|
static <K> RocksDBFullSnapshotResources<K> |
create(LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
KeyGroupRange keyGroupRange,
TypeSerializer<K> keySerializer,
int keyGroupPrefixBytes,
StreamCompressionDecorator keyGroupCompressionDecorator) |
KeyValueStateIterator |
createKVStateIterator()
Returns a
KeyValueStateIterator for iterating over all key-value states for this
snapshot resources. |
KeyGroupRange |
getKeyGroupRange()
Returns the
KeyGroupRange of this snapshot. |
TypeSerializer<K> |
getKeySerializer()
Returns key
TypeSerializer . |
List<StateMetaInfoSnapshot> |
getMetaInfoSnapshots()
Returns the list of
meta info snapshots for this state
snapshot. |
StreamCompressionDecorator |
getStreamCompressionDecorator()
Returns the
StreamCompressionDecorator that should be used for writing. |
void |
release()
Cleans up the resources after the asynchronous part is done.
|
public RocksDBFullSnapshotResources(ResourceGuard.Lease lease, org.rocksdb.Snapshot snapshot, List<RocksDBKeyedStateBackend.RocksDbKvStateInfo> metaDataCopy, List<HeapPriorityQueueStateSnapshot<?>> heapPriorityQueuesSnapshots, List<StateMetaInfoSnapshot> stateMetaInfoSnapshots, org.rocksdb.RocksDB db, int keyGroupPrefixBytes, KeyGroupRange keyGroupRange, TypeSerializer<K> keySerializer, StreamCompressionDecorator streamCompressionDecorator)
public static <K> RocksDBFullSnapshotResources<K> create(LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation, Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates, org.rocksdb.RocksDB db, ResourceGuard rocksDBResourceGuard, KeyGroupRange keyGroupRange, TypeSerializer<K> keySerializer, int keyGroupPrefixBytes, StreamCompressionDecorator keyGroupCompressionDecorator) throws IOException
IOException
public KeyValueStateIterator createKVStateIterator() throws IOException
FullSnapshotResources
KeyValueStateIterator
for iterating over all key-value states for this
snapshot resources.createKVStateIterator
in interface FullSnapshotResources<K>
IOException
public List<StateMetaInfoSnapshot> getMetaInfoSnapshots()
FullSnapshotResources
meta info snapshots
for this state
snapshot.getMetaInfoSnapshots
in interface FullSnapshotResources<K>
public KeyGroupRange getKeyGroupRange()
FullSnapshotResources
KeyGroupRange
of this snapshot.getKeyGroupRange
in interface FullSnapshotResources<K>
public TypeSerializer<K> getKeySerializer()
FullSnapshotResources
TypeSerializer
.getKeySerializer
in interface FullSnapshotResources<K>
public StreamCompressionDecorator getStreamCompressionDecorator()
FullSnapshotResources
StreamCompressionDecorator
that should be used for writing.getStreamCompressionDecorator
in interface FullSnapshotResources<K>
public void release()
SnapshotResources
release
in interface SnapshotResources
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.