Modifier and Type | Method and Description |
---|---|
static RocksDBKeyedStateBackend.RocksDbKvStateInfo |
RocksDBOperationUtils.createStateInfo(RegisteredStateMetaInfoBase metaInfoBase,
org.rocksdb.RocksDB db,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
Long writeBufferManagerCapacity)
Creates a state info from a new meta info to use with a k/v state.
|
Modifier and Type | Method and Description |
---|---|
static void |
RocksDBOperationUtils.registerKvStateInformation(Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
RocksDBNativeMetricMonitor nativeMetricMonitor,
String columnFamilyName,
RocksDBKeyedStateBackend.RocksDbKvStateInfo registeredColumn) |
Modifier and Type | Method and Description |
---|---|
static void |
RocksDBOperationUtils.registerKvStateInformation(Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
RocksDBNativeMetricMonitor nativeMetricMonitor,
String columnFamilyName,
RocksDBKeyedStateBackend.RocksDbKvStateInfo registeredColumn) |
Constructor and Description |
---|
RocksDBKeyedStateBackend(ClassLoader userCodeClassLoader,
File instanceBasePath,
RocksDBResourceContainer optionsContainer,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
org.rocksdb.RocksDB db,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
int keyGroupPrefixBytes,
CloseableRegistry cancelStreamRegistry,
StreamCompressionDecorator keyGroupCompressionDecorator,
ResourceGuard rocksDBResourceGuard,
RocksDBSnapshotStrategyBase<K,?> checkpointSnapshotStrategy,
RocksDBWriteBatchWrapper writeBatchWrapper,
org.rocksdb.ColumnFamilyHandle defaultColumnFamilyHandle,
RocksDBNativeMetricMonitor nativeMetricMonitor,
SerializedCompositeKeyBuilder<K> sharedRocksKeyBuilder,
PriorityQueueSetFactory priorityQueueFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
InternalKeyContext<K> keyContext,
long writeBatchSize,
CompletableFuture<Void> asyncCompactFuture,
RocksDBManualCompactionManager rocksDBManualCompactionManager) |
Constructor and Description |
---|
RocksDBFullRestoreOperation(KeyGroupRange keyGroupRange,
ClassLoader userCodeClassLoader,
Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
StateSerializerProvider<K> keySerializerProvider,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
Collection<KeyedStateHandle> restoreStateHandles,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
long writeBatchSize,
Long writeBufferManagerCapacity) |
RocksDBHeapTimersFullRestoreOperation(KeyGroupRange keyGroupRange,
int numberOfKeyGroups,
ClassLoader userCodeClassLoader,
Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
LinkedHashMap<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
HeapPriorityQueueSetFactory priorityQueueFactory,
StateSerializerProvider<K> keySerializerProvider,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
Collection<KeyedStateHandle> restoreStateHandles,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
long writeBatchSize,
Long writeBufferManagerCapacity) |
RocksDBIncrementalRestoreOperation(String operatorIdentifier,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
int numberOfTransferringThreads,
CloseableRegistry cancelStreamRegistry,
ClassLoader userCodeClassLoader,
Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
StateSerializerProvider<K> keySerializerProvider,
File instanceBasePath,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
StateBackend.CustomInitializationMetrics customInitializationMetrics,
Collection<IncrementalKeyedStateHandle> restoreStateHandles,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
long writeBatchSize,
Long writeBufferManagerCapacity,
double overlapFractionThreshold,
boolean useIngestDbRestoreMode,
boolean asyncCompactAfterRescale,
boolean useDeleteFilesInRange,
ExecutorService ioExecutor) |
RocksDBNoneRestoreOperation(Map<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
File instanceRocksDBPath,
org.rocksdb.DBOptions dbOptions,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDBNativeMetricOptions nativeMetricOptions,
MetricGroup metricGroup,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
Long writeBufferManagerCapacity) |
Modifier and Type | Field and Description |
---|---|
protected LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> |
RocksDBSnapshotStrategyBase.kvStateInformation
Key/Value state meta info from the backend.
|
Modifier and Type | Method and Description |
---|---|
static <K> RocksDBFullSnapshotResources<K> |
RocksDBFullSnapshotResources.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) |
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) |
RocksDBSnapshotStrategyBase(String description,
org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
File instanceBasePath,
UUID backendUID) |
RocksIncrementalSnapshotStrategy(org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
File instanceBasePath,
UUID backendUID,
SortedMap<Long,Collection<IncrementalKeyedStateHandle.HandleAndLocalPath>> uploadedStateHandles,
RocksDBStateUploader rocksDBStateUploader,
long lastCompletedCheckpointId) |
RocksNativeFullSnapshotStrategy(org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
File instanceBasePath,
UUID backendUID,
RocksDBStateUploader rocksDBStateUploader) |
Modifier and Type | Method and Description |
---|---|
void |
RocksDBManualCompactionManager.register(RocksDBKeyedStateBackend.RocksDbKvStateInfo stateInfo) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.