Uses of Interface
org.apache.flink.runtime.state.StateBackend
-
-
Uses of StateBackend in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return StateBackend Modifier and Type Method Description static StateBackendCheckpoints. loadStateBackend(org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger) -
Uses of StateBackend in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type StateBackend Modifier and Type Method Description voidDefaultExecutionGraph. enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig, List<MasterTriggerRestoreHook<?>> masterHooks, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore checkpointStore, StateBackend checkpointStateBackend, CheckpointStorage checkpointStorage, CheckpointStatsTracker statsTracker, CheckpointsCleaner checkpointsCleaner, String changelogStorageName)voidExecutionGraph. enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig, List<MasterTriggerRestoreHook<?>> masterHooks, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore checkpointStore, StateBackend checkpointStateBackend, CheckpointStorage checkpointStorage, CheckpointStatsTracker statsTracker, CheckpointsCleaner checkpointsCleaner, String changelogStorage) -
Uses of StateBackend in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return types with arguments of type StateBackend Modifier and Type Method Description org.apache.flink.util.SerializedValue<StateBackend>JobCheckpointingSettings. getDefaultStateBackend()Constructor parameters in org.apache.flink.runtime.jobgraph.tasks with type arguments of type StateBackend Constructor Description JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, org.apache.flink.util.SerializedValue<StateBackend> defaultStateBackend)JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, org.apache.flink.util.SerializedValue<StateBackend> defaultStateBackend, org.apache.flink.util.TernaryBoolean changelogStateBackendEnabled, org.apache.flink.util.SerializedValue<CheckpointStorage> defaultCheckpointStorage, org.apache.flink.util.SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks)JobCheckpointingSettings(CheckpointCoordinatorConfiguration checkpointCoordinatorConfiguration, org.apache.flink.util.SerializedValue<StateBackend> defaultStateBackend, org.apache.flink.util.TernaryBoolean changelogStateBackendEnabled, org.apache.flink.util.SerializedValue<CheckpointStorage> defaultCheckpointStorage, org.apache.flink.util.SerializedValue<MasterTriggerRestoreHook.Factory[]> masterHooks, org.apache.flink.util.TernaryBoolean stateBackendUseManagedMemory) -
Uses of StateBackend in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state with type parameters of type StateBackend Modifier and Type Interface Description interfaceStateBackendFactory<T extends StateBackend>A factory to create a specific state backend.Subinterfaces of StateBackend in org.apache.flink.runtime.state Modifier and Type Interface Description interfaceConfigurableStateBackendAn interface for state backends that pick up additional parameters from a configuration.Classes in org.apache.flink.runtime.state that implement StateBackend Modifier and Type Class Description classAbstractManagedMemoryStateBackendAbstract base class for state backends that use managed memory.classAbstractStateBackendAn abstract base implementation of theStateBackendinterface.Methods in org.apache.flink.runtime.state that return StateBackend Modifier and Type Method Description StateBackendConfigurableStateBackend. configure(org.apache.flink.configuration.ReadableConfig config, ClassLoader classLoader)Creates a variant of the state backend that applies additional configuration parameters.static StateBackendStateBackendLoader. fromApplicationOrConfigOrDefault(StateBackend fromApplication, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger)This is the state backend loader that loads aDelegatingStateBackendwrapping the state backend loaded fromStateBackendLoader.loadFromApplicationOrConfigOrDefaultInternal(org.apache.flink.runtime.state.StateBackend, org.apache.flink.configuration.Configuration, org.apache.flink.configuration.Configuration, java.lang.ClassLoader, org.slf4j.Logger)when delegation is enabled.static StateBackendStateBackendLoader. loadStateBackendFromConfig(org.apache.flink.configuration.ReadableConfig config, ClassLoader classLoader, org.slf4j.Logger logger)Loads the unwrapped state backend from the configuration, from the parameter 'state.backend', as defined inStateBackendOptions.STATE_BACKEND.static StateBackendStateBackendLoader. loadStateBackendFromKeyedStateHandles(StateBackend originalStateBackend, ClassLoader classLoader, Collection<KeyedStateHandle> keyedStateHandles)Load state backend which may wrap the original state backend for recovery.Methods in org.apache.flink.runtime.state with parameters of type StateBackend Modifier and Type Method Description static StateBackendStateBackendLoader. fromApplicationOrConfigOrDefault(StateBackend fromApplication, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger)This is the state backend loader that loads aDelegatingStateBackendwrapping the state backend loaded fromStateBackendLoader.loadFromApplicationOrConfigOrDefaultInternal(org.apache.flink.runtime.state.StateBackend, org.apache.flink.configuration.Configuration, org.apache.flink.configuration.Configuration, java.lang.ClassLoader, org.slf4j.Logger)when delegation is enabled.static booleanStateBackendLoader. isChangelogStateBackend(StateBackend backend)static CheckpointStorageCheckpointStorageLoader. load(CheckpointStorage fromApplication, StateBackend configuredStateBackend, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger)Loads the configuredCheckpointStoragefor the job based on the following precedent rules:static StateBackendStateBackendLoader. loadStateBackendFromKeyedStateHandles(StateBackend originalStateBackend, ClassLoader classLoader, Collection<KeyedStateHandle> keyedStateHandles)Load state backend which may wrap the original state backend for recovery. -
Uses of StateBackend in org.apache.flink.runtime.state.delegate
Subinterfaces of StateBackend in org.apache.flink.runtime.state.delegate Modifier and Type Interface Description interfaceDelegatingStateBackendAn interface to delegate state backend.Methods in org.apache.flink.runtime.state.delegate that return StateBackend Modifier and Type Method Description StateBackendDelegatingStateBackend. getDelegatedStateBackend() -
Uses of StateBackend in org.apache.flink.runtime.state.filesystem
Classes in org.apache.flink.runtime.state.filesystem that implement StateBackend Modifier and Type Class Description classAbstractFileStateBackendDeprecated.State backends should no longer implementCheckpointStoragefunctionality. -
Uses of StateBackend in org.apache.flink.runtime.state.hashmap
Classes in org.apache.flink.runtime.state.hashmap that implement StateBackend Modifier and Type Class Description classHashMapStateBackendThis state backend holds the working state in the memory (JVM heap) of the TaskManagers and checkpoints based on the configuredCheckpointStorage. -
Uses of StateBackend in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return StateBackend Modifier and Type Method Description StateBackendStreamConfig. getStateBackend(ClassLoader cl)StateBackendStreamGraph. getStateBackend()Methods in org.apache.flink.streaming.api.graph with parameters of type StateBackend Modifier and Type Method Description voidStreamConfig. setStateBackend(StateBackend backend)voidStreamGraph. setStateBackend(StateBackend backend)Method parameters in org.apache.flink.streaming.api.graph with type arguments of type StateBackend Modifier and Type Method Description voidStreamConfig. setSerializedStateBackend(org.apache.flink.util.SerializedValue<StateBackend> serializedStateBackend, boolean useManagedMemory) -
Uses of StateBackend in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type StateBackend Modifier and Type Method Description RStreamTaskStateInitializerImpl.KeyedStateBackendCreator. create(StateBackend stateBackend, StateBackend.KeyedStateBackendParameters<K> keyedStateBackendParameters)Create the keyed state backend.Constructors in org.apache.flink.streaming.api.operators with parameters of type StateBackend Constructor Description StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend)StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend, SubTaskInitializationMetricsBuilder initializationMetrics, TtlTimeProvider ttlTimeProvider, InternalTimeServiceManager.Provider timeServiceManagerProvider, StreamTaskCancellationContext cancellationContext) -
Uses of StateBackend in org.apache.flink.streaming.api.operators.sorted.state
Classes in org.apache.flink.streaming.api.operators.sorted.state that implement StateBackend Modifier and Type Class Description classBatchExecutionStateBackendA simpleStateBackendwhich is used in a BATCH style execution. -
Uses of StateBackend in org.apache.flink.streaming.runtime.tasks
Fields in org.apache.flink.streaming.runtime.tasks declared as StateBackend Modifier and Type Field Description protected StateBackendStreamTask. stateBackendOur state backend.
-