Uses of Class
org.apache.flink.util.ResourceGuard
-
-
Uses of ResourceGuard in org.apache.flink.state.forst.snapshot
Fields in org.apache.flink.state.forst.snapshot declared as ResourceGuard Modifier and Type Field Description protected ResourceGuard
ForStSnapshotStrategyBase. resourceGuard
Resource guard for the ForSt instance.Constructors in org.apache.flink.state.forst.snapshot with parameters of type ResourceGuard Constructor Description ForStIncrementalSnapshotStrategy(org.forstdb.RocksDB db, ResourceGuard forstResourceGuard, ForStResourceContainer resourceContainer, TypeSerializer<K> keySerializer, LinkedHashMap<String,ForStOperationUtils.ForStKvStateInfo> kvStateInformation, KeyGroupRange keyGroupRange, int keyGroupPrefixBytes, UUID backendUID, SortedMap<Long,Collection<IncrementalKeyedStateHandle.HandleAndLocalPath>> uploadedStateHandles, ForStStateDataTransfer stateTransfer, long lastCompletedCheckpointId)
ForStNativeFullSnapshotStrategy(String description, org.forstdb.RocksDB db, ResourceGuard resourceGuard, ForStResourceContainer resourceContainer, TypeSerializer<K> keySerializer, LinkedHashMap<String,ForStOperationUtils.ForStKvStateInfo> kvStateInformation, KeyGroupRange keyGroupRange, int keyGroupPrefixBytes, UUID backendUID, ForStStateDataTransfer stateTransfer)
ForStNativeFullSnapshotStrategy(org.forstdb.RocksDB db, ResourceGuard resourceGuard, ForStResourceContainer resourceContainer, TypeSerializer<K> keySerializer, LinkedHashMap<String,ForStOperationUtils.ForStKvStateInfo> kvStateInformation, KeyGroupRange keyGroupRange, int keyGroupPrefixBytes, UUID backendUID, ForStStateDataTransfer stateTransfer)
ForStSnapshotStrategyBase(String description, org.forstdb.RocksDB db, ResourceGuard resourceGuard, ForStResourceContainer resourceContainer, TypeSerializer<K> keySerializer, LinkedHashMap<String,ForStOperationUtils.ForStKvStateInfo> kvStateInformation, KeyGroupRange keyGroupRange, int keyGroupPrefixBytes, UUID backendUID)
-
Uses of ResourceGuard in org.apache.flink.state.forst.sync
Constructors in org.apache.flink.state.forst.sync with parameters of type ResourceGuard Constructor Description ForStSyncKeyedStateBackend(ClassLoader userCodeClassLoader, Path instanceBasePath, ForStResourceContainer optionsContainer, Function<String,org.forstdb.ColumnFamilyOptions> columnFamilyOptionsFactory, TaskKvStateRegistry kvStateRegistry, TypeSerializer<K> keySerializer, ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, org.forstdb.RocksDB db, LinkedHashMap<String,ForStOperationUtils.ForStKvStateInfo> kvStateInformation, Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates, int keyGroupPrefixBytes, CloseableRegistry cancelStreamRegistry, StreamCompressionDecorator keyGroupCompressionDecorator, ResourceGuard rocksDBResourceGuard, ForStSnapshotStrategyBase<K,?> checkpointSnapshotStrategy, ForStDBWriteBatchWrapper writeBatchWrapper, org.forstdb.ColumnFamilyHandle defaultColumnFamilyHandle, ForStNativeMetricMonitor nativeMetricMonitor, SerializedCompositeKeyBuilder<K> sharedRocksKeyBuilder, PriorityQueueSetFactory priorityQueueFactory, ForStDBTtlCompactFiltersManager ttlCompactFiltersManager, InternalKeyContext<K> keyContext, long writeBatchSize, CompletableFuture<Void> asyncCompactFuture)
-
Uses of ResourceGuard in org.apache.flink.state.rocksdb
Methods in org.apache.flink.state.rocksdb with parameters of type ResourceGuard Modifier and Type Method Description static RunnableWithException
RocksDBIncrementalCheckpointUtils. createAsyncRangeCompactionTask(org.rocksdb.RocksDB db, Collection<org.rocksdb.ColumnFamilyHandle> columnFamilyHandles, int keyGroupPrefixBytes, KeyGroupRange dbExpectedKeyGroupRange, ResourceGuard rocksDBResourceGuard, CloseableRegistry closeableRegistry)
Returns a range compaction task as runnable if any data in the SST files of the given DB exceeds the proclaimed key-group range.Constructors in org.apache.flink.state.rocksdb with parameters of type ResourceGuard Constructor 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)
-
Uses of ResourceGuard in org.apache.flink.state.rocksdb.restore
Constructors in org.apache.flink.state.rocksdb.restore with parameters of type ResourceGuard Constructor Description RocksDBIncrementalRestoreOperation(String operatorIdentifier, KeyGroupRange keyGroupRange, int keyGroupPrefixBytes, int numberOfTransferringThreads, ResourceGuard dbResourceGuard, CloseableRegistry cancelStreamRegistryForRestore, CloseableRegistry cancelRegistryForBackend, 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, AsyncExceptionHandler asyncExceptionHandler)
-
Uses of ResourceGuard in org.apache.flink.state.rocksdb.snapshot
Fields in org.apache.flink.state.rocksdb.snapshot declared as ResourceGuard Modifier and Type Field Description protected ResourceGuard
RocksDBSnapshotStrategyBase. rocksDBResourceGuard
Resource guard for the RocksDB instance.Methods in org.apache.flink.state.rocksdb.snapshot with parameters of type ResourceGuard Modifier and Type Method 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)
Constructors in org.apache.flink.state.rocksdb.snapshot with parameters of type ResourceGuard Constructor Description 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)
-