Modifier and Type | Method and Description |
---|---|
EmbeddedRocksDBStateBackend |
EmbeddedRocksDBStateBackendFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader) |
RocksDBStateBackend |
RocksDBStateBackendFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static void |
FileSystem.initialize(Configuration config)
Deprecated.
use
FileSystem.initialize(Configuration, PluginManager) instead. |
static void |
FileSystem.initialize(Configuration config,
PluginManager pluginManager)
Initializes the shared file system settings.
|
Modifier and Type | Method and Description |
---|---|
CheckpointStorage |
ConfigurableCheckpointStorage.configure(ReadableConfig config,
ClassLoader classLoader)
Creates a variant of the checkpoint storage that applies additional configuration parameters.
|
StateBackend |
ConfigurableStateBackend.configure(ReadableConfig config,
ClassLoader classLoader)
Creates a variant of the state backend that applies additional configuration parameters.
|
T |
StateBackendFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader)
Creates the state backend, optionally using the given configuration.
|
T |
CheckpointStorageFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader)
Creates the checkpoint storage, optionally using the given configuration.
|
static StateBackend |
StateBackendLoader.fromApplicationOrConfigOrDefault(StateBackend fromApplication,
Configuration jobConfig,
Configuration clusterConfig,
ClassLoader classLoader,
org.slf4j.Logger logger)
This is the state backend loader that loads a
DelegatingStateBackend wrapping the
state backend loaded from StateBackendLoader.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 CheckpointStorage |
CheckpointStorageLoader.load(CheckpointStorage fromApplication,
StateBackend configuredStateBackend,
Configuration jobConfig,
Configuration clusterConfig,
ClassLoader classLoader,
org.slf4j.Logger logger)
Loads the configured
CheckpointStorage for the job based on the following precedent
rules:
1) If the jobs configured StateBackend implements CheckpointStorage it
will always be used. |
static StateBackend |
StateBackendLoader.loadStateBackendFromConfig(ReadableConfig config,
ClassLoader classLoader,
org.slf4j.Logger logger)
Loads the unwrapped state backend from the configuration, from the parameter 'state.backend',
as defined in
StateBackendOptions.STATE_BACKEND . |
Modifier and Type | Method and Description |
---|---|
FsStateBackend |
FsStateBackendFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader) |
Modifier and Type | Method and Description |
---|---|
HashMapStateBackend |
HashMapStateBackend.configure(ReadableConfig config,
ClassLoader classLoader) |
HashMapStateBackend |
HashMapStateBackendFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader) |
Modifier and Type | Method and Description |
---|---|
FileSystemCheckpointStorage |
FileSystemCheckpointStorage.configure(ReadableConfig config,
ClassLoader classLoader) |
static FileSystemCheckpointStorage |
FileSystemCheckpointStorage.createFromConfig(ReadableConfig config,
ClassLoader classLoader)
Creates a new
FileSystemCheckpointStorage using the given configuration. |
static JobManagerCheckpointStorage |
JobManagerCheckpointStorage.createFromConfig(ReadableConfig config,
ClassLoader classLoader)
Creates a new
JobManagerCheckpointStorage using the given configuration. |
Modifier and Type | Method and Description |
---|---|
static void |
ConfigurationParserUtils.checkConfigParameter(boolean condition,
Object parameter,
String name,
String errorMessage)
Validates a condition for a config parameter and displays a standard exception, if the
condition does not hold.
|
static String |
ZooKeeperUtils.getZooKeeperEnsemble(Configuration flinkConf)
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not
tolerate it).
|
Modifier and Type | Method and Description |
---|---|
StateBackend |
ChangelogStateBackend.configure(ReadableConfig config,
ClassLoader classLoader) |
Modifier and Type | Method and Description |
---|---|
ForStStateBackend |
ForStStateBackendFactory.createFromConfig(ReadableConfig config,
ClassLoader classLoader) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.