Uses of Class
org.apache.flink.runtime.state.LocalRecoveryConfig
-
Packages that use LocalRecoveryConfig Package Description org.apache.flink.changelog.fs org.apache.flink.contrib.streaming.state org.apache.flink.contrib.streaming.state.snapshot org.apache.flink.runtime.state org.apache.flink.runtime.state.changelog org.apache.flink.runtime.state.changelog.inmemory org.apache.flink.runtime.state.heap This package contains the classes for key/value state backends that store the state on the JVM heap as objects.org.apache.flink.state.forst.sync -
-
Uses of LocalRecoveryConfig in org.apache.flink.changelog.fs
Methods in org.apache.flink.changelog.fs with parameters of type LocalRecoveryConfig Modifier and Type Method Description StateChangelogStorage<?>
FsStateChangelogStorageFactory. createStorage(JobID jobID, Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
static StateChangeUploadScheduler
StateChangeUploadScheduler. fromConfig(JobID jobID, ReadableConfig config, ChangelogStorageMetricGroup metricGroup, TaskChangelogRegistry changelogRegistry, LocalRecoveryConfig localRecoveryConfig)
Constructors in org.apache.flink.changelog.fs with parameters of type LocalRecoveryConfig Constructor Description FsStateChangelogStorage(JobID jobID, Configuration config, TaskManagerJobMetricGroup metricGroup, TaskChangelogRegistry changelogRegistry, LocalRecoveryConfig localRecoveryConfig)
FsStateChangelogStorage(JobID jobID, Configuration config, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
FsStateChangelogStorage(JobID jobID, Path basePath, boolean compression, int bufferSize, ChangelogStorageMetricGroup metricGroup, TaskChangelogRegistry changelogRegistry, LocalRecoveryConfig localRecoveryConfig)
FsStateChangelogStorage(StateChangeUploadScheduler uploader, long preEmptivePersistThresholdInBytes, TaskChangelogRegistry changelogRegistry, LocalRecoveryConfig localRecoveryConfig)
-
Uses of LocalRecoveryConfig in org.apache.flink.contrib.streaming.state
Constructors in org.apache.flink.contrib.streaming.state with parameters of type LocalRecoveryConfig Constructor Description RocksDBKeyedStateBackendBuilder(String operatorIdentifier, ClassLoader userCodeClassLoader, File instanceBasePath, RocksDBResourceContainer optionsContainer, Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory, TaskKvStateRegistry kvStateRegistry, TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, ExecutionConfig executionConfig, LocalRecoveryConfig localRecoveryConfig, RocksDBPriorityQueueConfig priorityQueueConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, MetricGroup metricGroup, StateBackend.CustomInitializationMetrics customInitializationMetrics, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, CloseableRegistry cancelStreamRegistry)
-
Uses of LocalRecoveryConfig in org.apache.flink.contrib.streaming.state.snapshot
Fields in org.apache.flink.contrib.streaming.state.snapshot declared as LocalRecoveryConfig Modifier and Type Field Description protected LocalRecoveryConfig
RocksDBSnapshotStrategyBase. localRecoveryConfig
The configuration for local recovery.Constructors in org.apache.flink.contrib.streaming.state.snapshot with parameters of type LocalRecoveryConfig 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)
-
Uses of LocalRecoveryConfig in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state declared as LocalRecoveryConfig Modifier and Type Field Description static LocalRecoveryConfig
LocalRecoveryConfig. BACKUP_AND_RECOVERY_DISABLED
protected LocalRecoveryConfig
TaskLocalStateStoreImpl. localRecoveryConfig
The configured mode for local recovery.Methods in org.apache.flink.runtime.state that return LocalRecoveryConfig Modifier and Type Method Description static LocalRecoveryConfig
LocalRecoveryConfig. backupAndRecoveryEnabled(LocalSnapshotDirectoryProvider directoryProvider)
LocalRecoveryConfig
TaskStateManager. createLocalRecoveryConfig()
Returns the configuration for local recovery, i.e. the base directories for all file-based local state of the owning subtask and the general mode for local recovery.LocalRecoveryConfig
TaskStateManagerImpl. createLocalRecoveryConfig()
LocalRecoveryConfig
NoOpTaskLocalStateStoreImpl. getLocalRecoveryConfig()
LocalRecoveryConfig
TaskLocalStateStore. getLocalRecoveryConfig()
Returns theLocalRecoveryConfig
for this task local state store.LocalRecoveryConfig
TaskLocalStateStoreImpl. getLocalRecoveryConfig()
Methods in org.apache.flink.runtime.state with parameters of type LocalRecoveryConfig Modifier and Type Method Description StateChangelogStorage<?>
TaskExecutorStateChangelogStoragesManager. stateChangelogStorageForJob(JobID jobId, Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
Constructors in org.apache.flink.runtime.state with parameters of type LocalRecoveryConfig Constructor Description ChangelogTaskLocalStateStore(JobID jobID, AllocationID allocationID, JobVertexID jobVertexID, int subtaskIndex, LocalRecoveryConfig localRecoveryConfig, Executor discardExecutor)
TaskLocalStateStoreImpl(JobID jobID, AllocationID allocationID, JobVertexID jobVertexID, int subtaskIndex, LocalRecoveryConfig localRecoveryConfig, Executor discardExecutor)
-
Uses of LocalRecoveryConfig in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog with parameters of type LocalRecoveryConfig Modifier and Type Method Description StateChangelogStorage<?>
StateChangelogStorageFactory. createStorage(JobID jobID, Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
Create the storage based on a configuration.static StateChangelogStorage<?>
StateChangelogStorageLoader. load(JobID jobID, Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
-
Uses of LocalRecoveryConfig in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory with parameters of type LocalRecoveryConfig Modifier and Type Method Description StateChangelogStorage<?>
InMemoryStateChangelogStorageFactory. createStorage(JobID jobID, Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
-
Uses of LocalRecoveryConfig in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap that return LocalRecoveryConfig Modifier and Type Method Description LocalRecoveryConfig
HeapKeyedStateBackend. getLocalRecoveryConfig()
Constructors in org.apache.flink.runtime.state.heap with parameters of type LocalRecoveryConfig Constructor Description HeapKeyedStateBackend(TaskKvStateRegistry kvStateRegistry, TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, CloseableRegistry cancelStreamRegistry, StreamCompressionDecorator keyGroupCompressionDecorator, Map<String,StateTable<K,?,?>> registeredKVStates, Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, org.apache.flink.runtime.state.heap.HeapSnapshotStrategy<K> checkpointStrategy, SnapshotExecutionType snapshotExecutionType, org.apache.flink.runtime.state.heap.StateTableFactory<K> stateTableFactory, InternalKeyContext<K> keyContext)
HeapKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, CloseableRegistry cancelStreamRegistry)
-
Uses of LocalRecoveryConfig in org.apache.flink.state.forst.sync
Constructors in org.apache.flink.state.forst.sync with parameters of type LocalRecoveryConfig Constructor Description ForStSyncKeyedStateBackendBuilder(String operatorIdentifier, ClassLoader userCodeClassLoader, File instanceBasePath, ForStResourceContainer optionsContainer, Function<String,org.forstdb.ColumnFamilyOptions> columnFamilyOptionsFactory, TaskKvStateRegistry kvStateRegistry, TypeSerializer<K> keySerializer, int numberOfKeyGroups, KeyGroupRange keyGroupRange, ExecutionConfig executionConfig, LocalRecoveryConfig localRecoveryConfig, ForStPriorityQueueConfig priorityQueueConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, MetricGroup metricGroup, StateBackend.CustomInitializationMetrics customInitializationMetrics, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, CloseableRegistry cancelStreamRegistry)
-