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 LocalRecoveryConfigLocalRecoveryConfig. BACKUP_AND_RECOVERY_DISABLEDprotected LocalRecoveryConfigTaskLocalStateStoreImpl. localRecoveryConfigThe configured mode for local recovery.Methods in org.apache.flink.runtime.state that return LocalRecoveryConfig Modifier and Type Method Description static LocalRecoveryConfigLocalRecoveryConfig. backupAndRecoveryEnabled(LocalSnapshotDirectoryProvider directoryProvider)LocalRecoveryConfigTaskStateManager. 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.LocalRecoveryConfigTaskStateManagerImpl. createLocalRecoveryConfig()LocalRecoveryConfigNoOpTaskLocalStateStoreImpl. getLocalRecoveryConfig()LocalRecoveryConfigTaskLocalStateStore. getLocalRecoveryConfig()Returns theLocalRecoveryConfigfor this task local state store.LocalRecoveryConfigTaskLocalStateStoreImpl. 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 LocalRecoveryConfigHeapKeyedStateBackend. 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, SizeTrackingStateConfig sizeTrackingStateConfig, 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, SizeTrackingStateConfig sizeTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
-