Uses of Class
org.apache.flink.runtime.state.LocalRecoveryConfig
-
Packages that use LocalRecoveryConfig Package Description 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. -
-
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(org.apache.flink.api.common.JobID jobId, org.apache.flink.configuration.Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
Constructors in org.apache.flink.runtime.state with parameters of type LocalRecoveryConfig Constructor Description ChangelogTaskLocalStateStore(org.apache.flink.api.common.JobID jobID, AllocationID allocationID, JobVertexID jobVertexID, int subtaskIndex, LocalRecoveryConfig localRecoveryConfig, Executor discardExecutor)
TaskLocalStateStoreImpl(org.apache.flink.api.common.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(org.apache.flink.api.common.JobID jobID, org.apache.flink.configuration.Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
Create the storage based on a configuration.static StateChangelogStorage<?>
StateChangelogStorageLoader. load(org.apache.flink.api.common.JobID jobID, org.apache.flink.configuration.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(org.apache.flink.api.common.JobID jobID, org.apache.flink.configuration.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, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, org.apache.flink.core.fs.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, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
-