Modifier and Type | Method and Description |
---|---|
static Set<Map.Entry<String,DistributedCache.DistributedCacheEntry>> |
DistributedCache.readFileInfoFromConfig(Configuration conf) |
static void |
DistributedCache.writeFileInfoToConfig(String name,
DistributedCache.DistributedCacheEntry e,
Configuration conf) |
Modifier and Type | Method and Description |
---|---|
ExternalResourceDriver |
ExternalResourceDriverFactory.createExternalResourceDriver(Configuration config)
Construct the ExternalResourceDriver from configuration.
|
Modifier and Type | Method and Description |
---|---|
void |
AbstractRichFunction.open(Configuration parameters) |
void |
RichFunction.open(Configuration parameters)
Initialization method for the function.
|
Modifier and Type | Method and Description |
---|---|
static void |
FunctionUtils.openFunction(Function function,
Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
InputFormat.configure(Configuration parameters)
Configures this input format.
|
void |
DelimitedInputFormat.configure(Configuration parameters)
Configures this input format by reading the path to the file from the configuration and the
string that defines the record delimiter.
|
void |
FileInputFormat.configure(Configuration parameters)
Configures the file input format by reading the file path from the configuration.
|
void |
FileOutputFormat.configure(Configuration parameters) |
void |
BinaryInputFormat.configure(Configuration parameters) |
void |
OutputFormat.configure(Configuration parameters)
Configures this output format.
|
void |
GenericInputFormat.configure(Configuration parameters) |
void |
BinaryOutputFormat.configure(Configuration parameters) |
void |
ReplicatingInputFormat.configure(Configuration parameters) |
static void |
FileOutputFormat.initDefaultsFromConfiguration(Configuration configuration)
Initialize defaults for output format.
|
protected static void |
DelimitedInputFormat.loadConfigParameters(Configuration parameters) |
Constructor and Description |
---|
DelimitedInputFormat(Path filePath,
Configuration configuration) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
Operator.parameters |
Modifier and Type | Method and Description |
---|---|
Configuration |
Operator.getParameters()
Gets the stub parameters of this contract.
|
Modifier and Type | Method and Description |
---|---|
void |
BulkIterationBase.TerminationCriterionMapper.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
TypeComparatorFactory.readParametersFromConfig(Configuration config,
ClassLoader cl) |
void |
TypeSerializerFactory.readParametersFromConfig(Configuration config,
ClassLoader cl) |
void |
TypeComparatorFactory.writeParametersToConfig(Configuration config) |
void |
TypeSerializerFactory.writeParametersToConfig(Configuration config) |
Modifier and Type | Method and Description |
---|---|
Configuration |
SourceReaderContext.getConfiguration()
Gets the configuration with which Flink was started.
|
Modifier and Type | Method and Description |
---|---|
Configuration |
ExecutionEnvironment.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
void |
Utils.CountHelper.configure(Configuration parameters) |
void |
Utils.CollectHelper.configure(Configuration parameters) |
void |
Utils.ChecksumHashCodeHelper.configure(Configuration parameters) |
static LocalEnvironment |
ExecutionEnvironment.createLocalEnvironment(Configuration customConfiguration)
Creates a
LocalEnvironment . |
static ExecutionEnvironment |
ExecutionEnvironment.createLocalEnvironmentWithWebUI(Configuration conf)
Creates a
LocalEnvironment for local program execution that also starts the web
monitoring UI. |
static ExecutionEnvironment |
ExecutionEnvironment.createRemoteEnvironment(String host,
int port,
Configuration clientConfiguration,
String... jarFiles)
Creates a
RemoteEnvironment . |
static void |
RemoteEnvironmentConfigUtils.setJarURLsToConfig(String[] jars,
Configuration configuration) |
static void |
RemoteEnvironmentConfigUtils.setJobManagerAddressToConfig(String host,
int port,
Configuration configuration) |
Constructor and Description |
---|
ExecutionEnvironment(Configuration configuration)
Creates a new
ExecutionEnvironment that will use the given Configuration to
configure the PipelineExecutor . |
ExecutionEnvironment(Configuration configuration,
ClassLoader userClassloader)
Creates a new
ExecutionEnvironment that will use the given Configuration to
configure the PipelineExecutor . |
ExecutionEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userClassloader)
Creates a new
ExecutionEnvironment that will use the given Configuration to
configure the PipelineExecutor . |
LocalEnvironment(Configuration config)
Creates a new local environment that configures its local executor with the given
configuration.
|
RemoteEnvironment(String host,
int port,
Configuration clientConfig,
String[] jarFiles)
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
host name and port.
|
RemoteEnvironment(String host,
int port,
Configuration clientConfig,
String[] jarFiles,
URL[] globalClasspaths)
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given
host name and port.
|
Modifier and Type | Method and Description |
---|---|
void |
HadoopOutputFormatBase.configure(Configuration parameters) |
void |
HadoopInputFormatBase.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
HadoopUtils.getHadoopConfiguration(Configuration flinkConfiguration)
Returns a new Hadoop Configuration object using the path to the hadoop conf configured in the
main configuration (flink-conf.yaml).
|
static String[] |
HadoopUtils.possibleHadoopConfPaths(Configuration flinkConfiguration)
Get possible Hadoop conf dir paths, based on environment variables and flink configuration.
|
Modifier and Type | Method and Description |
---|---|
void |
HadoopOutputFormatBase.configure(Configuration parameters) |
void |
HadoopInputFormatBase.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
PrintingOutputFormat.configure(Configuration parameters) |
void |
DiscardingOutputFormat.configure(Configuration parameters) |
void |
BlockingShuffleOutputFormat.configure(Configuration parameters) |
void |
TextValueInputFormat.configure(Configuration parameters) |
void |
LocalCollectionOutputFormat.configure(Configuration parameters) |
void |
TextInputFormat.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
Configuration |
TwoInputUdfOperator.getParameters() |
Configuration |
DataSource.getParameters() |
Configuration |
DataSink.getParameters() |
Configuration |
SingleInputUdfOperator.getParameters() |
Configuration |
UdfOperator.getParameters()
Gets the configuration parameters that will be passed to the UDF's open method
AbstractRichFunction.open(Configuration) . |
Modifier and Type | Method and Description |
---|---|
O |
TwoInputUdfOperator.withParameters(Configuration parameters) |
DataSource<OUT> |
DataSource.withParameters(Configuration parameters)
Pass a configuration to the InputFormat.
|
DataSink<T> |
DataSink.withParameters(Configuration parameters)
Pass a configuration to the OutputFormat.
|
O |
SingleInputUdfOperator.withParameters(Configuration parameters) |
O |
UdfOperator.withParameters(Configuration parameters)
Sets the configuration parameters for the UDF.
|
Modifier and Type | Method and Description |
---|---|
void |
WrappingFunction.open(Configuration parameters) |
void |
RichCombineToGroupCombineWrapper.open(Configuration config) |
Modifier and Type | Method and Description |
---|---|
void |
RuntimeComparatorFactory.readParametersFromConfig(Configuration config,
ClassLoader cl) |
void |
RuntimeSerializerFactory.readParametersFromConfig(Configuration config,
ClassLoader cl) |
void |
RuntimeComparatorFactory.writeParametersToConfig(Configuration config) |
void |
RuntimeSerializerFactory.writeParametersToConfig(Configuration config) |
Modifier and Type | Method and Description |
---|---|
Configuration |
ParameterTool.getConfiguration()
Returns a
Configuration object from this ParameterTool . |
Modifier and Type | Method and Description |
---|---|
void |
CassandraInputFormatBase.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
Generator.configure(Configuration parameters) |
void |
BlockingIncrementingMapFunction.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
PatternSelectAdapter.open(Configuration parameters) |
void |
PatternFlatSelectAdapter.open(Configuration parameters) |
void |
PatternTimeoutFlatSelectAdapter.open(Configuration parameters) |
void |
PatternTimeoutSelectAdapter.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
NFA.open(RuntimeContext cepRuntimeContext,
Configuration conf)
Initialization method for the NFA.
|
Modifier and Type | Method and Description |
---|---|
void |
RichIterativeCondition.open(Configuration parameters) |
void |
RichCompositeIterativeCondition.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
static void |
FsStateChangelogStorageFactory.configure(Configuration configuration,
File newFolder,
java.time.Duration uploadTimeout,
int maxUploadAttempts) |
StateChangelogStorage<?> |
FsStateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
StateChangelogStorageView<?> |
FsStateChangelogStorageFactory.createStorageView(Configuration configuration) |
Constructor and Description |
---|
FsStateChangelogStorage(JobID jobID,
Configuration config,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
FsStateChangelogStorage(JobID jobID,
Configuration config,
TaskManagerJobMetricGroup metricGroup,
TaskChangelogRegistry changelogRegistry,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
static URLClassLoader |
ClientUtils.buildUserCodeClassLoader(List<URL> jars,
List<URL> classpaths,
ClassLoader parent,
Configuration configuration) |
static void |
ClientUtils.executeProgram(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
PackagedProgram program,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
static JobGraph |
FlinkPipelineTranslationUtil.getJobGraph(ClassLoader userClassloader,
Pipeline pipeline,
Configuration optimizerConfiguration,
int defaultParallelism)
|
static JobGraph |
FlinkPipelineTranslationUtil.getJobGraphUnderUserClassLoader(ClassLoader userClassloader,
Pipeline pipeline,
Configuration configuration,
int defaultParallelism)
|
JobGraph |
FlinkPipelineTranslator.translateToJobGraph(Pipeline pipeline,
Configuration optimizerConfiguration,
int defaultParallelism)
|
JobGraph |
PlanTranslator.translateToJobGraph(Pipeline pipeline,
Configuration optimizerConfiguration,
int defaultParallelism) |
JobGraph |
StreamGraphTranslator.translateToJobGraph(Pipeline pipeline,
Configuration optimizerConfiguration,
int defaultParallelism) |
Modifier and Type | Method and Description |
---|---|
Configuration |
ExecutionConfigAccessor.applyToConfiguration(Configuration baseConfiguration) |
Configuration |
CliFrontend.getConfiguration()
Getter which returns a copy of the associated configuration.
|
Configuration |
GenericCLI.toConfiguration(org.apache.commons.cli.CommandLine commandLine) |
Configuration |
CustomCommandLine.toConfiguration(org.apache.commons.cli.CommandLine commandLine)
Materializes the command line arguments in the given
CommandLine to a Configuration and returns it. |
Configuration |
AbstractCustomCommandLine.toConfiguration(org.apache.commons.cli.CommandLine commandLine) |
Configuration |
DefaultCLI.toConfiguration(org.apache.commons.cli.CommandLine commandLine) |
Modifier and Type | Method and Description |
---|---|
void |
PythonProgramOptions.applyToConfiguration(Configuration configuration) |
void |
ProgramOptions.applyToConfiguration(Configuration configuration) |
Configuration |
ExecutionConfigAccessor.applyToConfiguration(Configuration baseConfiguration) |
static void |
ProgramOptionsUtils.configurePythonExecution(Configuration configuration,
PackagedProgram packagedProgram) |
protected void |
CliFrontend.executeProgram(Configuration configuration,
PackagedProgram program) |
static ExecutionConfigAccessor |
ExecutionConfigAccessor.fromConfiguration(Configuration configuration)
Creates an
ExecutionConfigAccessor based on the provided Configuration . |
static List<CustomCommandLine> |
CliFrontend.loadCustomCommandLines(Configuration configuration,
String configurationDirectory) |
<ClusterID> |
ApplicationDeployer.run(Configuration configuration,
ApplicationConfiguration applicationConfiguration)
Submits a user program for execution and runs the main user method on the cluster.
|
Constructor and Description |
---|
CliFrontend(Configuration configuration,
ClusterClientServiceLoader clusterClientServiceLoader,
List<CustomCommandLine> customCommandLines) |
CliFrontend(Configuration configuration,
List<CustomCommandLine> customCommandLines) |
GenericCLI(Configuration configuration,
String configDir) |
Modifier and Type | Method and Description |
---|---|
ClusterDescriptor<ClusterID> |
ClusterClientFactory.createClusterDescriptor(Configuration configuration)
Create a
ClusterDescriptor from the given configuration. |
StandaloneClusterDescriptor |
StandaloneClientFactory.createClusterDescriptor(Configuration configuration) |
<ClusterID> |
ClusterClientServiceLoader.getClusterClientFactory(Configuration configuration)
Discovers the appropriate
ClusterClientFactory based on the provided configuration. |
<ClusterID> |
DefaultClusterClientServiceLoader.getClusterClientFactory(Configuration configuration) |
ClusterID |
ClusterClientFactory.getClusterId(Configuration configuration)
Returns the cluster id if a cluster id is specified in the provided configuration, otherwise
it returns
null . |
StandaloneClusterId |
StandaloneClientFactory.getClusterId(Configuration configuration) |
ClusterSpecification |
ClusterClientFactory.getClusterSpecification(Configuration configuration)
Returns the
ClusterSpecification specified by the configuration and the command line
options. |
ClusterSpecification |
AbstractContainerizedClusterClientFactory.getClusterSpecification(Configuration configuration) |
ClusterSpecification |
StandaloneClientFactory.getClusterSpecification(Configuration configuration) |
boolean |
ClusterClientFactory.isCompatibleWith(Configuration configuration)
Returns
true if the current ClusterClientFactory is compatible with the
provided configuration, false otherwise. |
boolean |
StandaloneClientFactory.isCompatibleWith(Configuration configuration) |
Constructor and Description |
---|
StandaloneClusterDescriptor(Configuration config) |
Modifier and Type | Method and Description |
---|---|
void |
ApplicationConfiguration.applyToConfiguration(Configuration configuration) |
protected static void |
ApplicationClusterEntryPoint.configureExecution(Configuration configuration,
PackagedProgram program) |
static ApplicationDispatcherLeaderProcessFactoryFactory |
ApplicationDispatcherLeaderProcessFactoryFactory.create(Configuration configuration,
DispatcherFactory dispatcherFactory,
PackagedProgram program) |
protected DispatcherResourceManagerComponentFactory |
ApplicationClusterEntryPoint.createDispatcherResourceManagerComponentFactory(Configuration configuration) |
protected ExecutionGraphInfoStore |
ApplicationClusterEntryPoint.createSerializableExecutionGraphStore(Configuration configuration,
ScheduledExecutor scheduledExecutor) |
static ApplicationConfiguration |
ApplicationConfiguration.fromConfiguration(Configuration configuration) |
List<JobID> |
ApplicationRunner.run(DispatcherGateway dispatcherGateway,
PackagedProgram program,
Configuration configuration)
Runs the application using the provided
dispatcherGateway . |
List<JobID> |
DetachedApplicationRunner.run(DispatcherGateway dispatcherGateway,
PackagedProgram program,
Configuration configuration) |
Constructor and Description |
---|
ApplicationClusterEntryPoint(Configuration configuration,
PackagedProgram program,
ResourceManagerFactory<?> resourceManagerFactory) |
ApplicationDispatcherBootstrap(PackagedProgram application,
Collection<JobID> recoveredJobIds,
Configuration configuration,
DispatcherGateway dispatcherGateway,
ScheduledExecutor scheduledExecutor,
FatalErrorHandler errorHandler) |
ApplicationDispatcherGatewayServiceFactory(Configuration configuration,
DispatcherFactory dispatcherFactory,
PackagedProgram application,
RpcService rpcService,
PartialDispatcherServices partialDispatcherServices) |
Modifier and Type | Method and Description |
---|---|
<ClusterID> |
ApplicationClusterDeployer.run(Configuration configuration,
ApplicationConfiguration applicationConfiguration) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobClient> |
EmbeddedExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader) |
PipelineExecutor |
WebSubmissionExecutorFactory.getExecutor(Configuration configuration) |
PipelineExecutor |
EmbeddedExecutorFactory.getExecutor(Configuration configuration) |
PipelineExecutorFactory |
WebSubmissionExecutorServiceLoader.getExecutorFactory(Configuration configuration) |
PipelineExecutorFactory |
EmbeddedExecutorServiceLoader.getExecutorFactory(Configuration configuration) |
boolean |
WebSubmissionExecutorFactory.isCompatibleWith(Configuration configuration) |
boolean |
EmbeddedExecutorFactory.isCompatibleWith(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static LocalExecutor |
LocalExecutor.create(Configuration configuration) |
static LocalExecutor |
LocalExecutor.createWithFactory(Configuration configuration,
java.util.function.Function<MiniClusterConfiguration,MiniCluster> miniClusterFactory) |
CompletableFuture<JobClient> |
AbstractJobClusterExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader)
Deprecated.
|
CompletableFuture<JobClient> |
AbstractSessionClusterExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader) |
CompletableFuture<JobClient> |
LocalExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader) |
PipelineExecutor |
RemoteExecutorFactory.getExecutor(Configuration configuration) |
PipelineExecutor |
LocalExecutorFactory.getExecutor(Configuration configuration) |
static JobGraph |
PipelineExecutorUtils.getJobGraph(Pipeline pipeline,
Configuration configuration,
ClassLoader userClassloader)
|
CompletableFuture<Void> |
AbstractSessionClusterExecutor.invalidateClusterDataset(AbstractID clusterDatasetId,
Configuration configuration,
ClassLoader userCodeClassloader) |
boolean |
RemoteExecutorFactory.isCompatibleWith(Configuration configuration) |
boolean |
LocalExecutorFactory.isCompatibleWith(Configuration configuration) |
CompletableFuture<Set<AbstractID>> |
AbstractSessionClusterExecutor.listCompletedClusterDatasetIds(Configuration configuration,
ClassLoader userCodeClassloader) |
Modifier and Type | Method and Description |
---|---|
Configuration |
MiniClusterClient.getFlinkConfiguration() |
Configuration |
ClusterClient.getFlinkConfiguration()
Return the Flink configuration object.
|
Modifier and Type | Method and Description |
---|---|
static DefaultPackagedProgramRetriever |
DefaultPackagedProgramRetriever.create(File userLibDir,
File jarFile,
String jobClassName,
String[] programArgs,
Configuration configuration)
Creates a
PackageProgramRetrieverImpl with the given parameters. |
static DefaultPackagedProgramRetriever |
DefaultPackagedProgramRetriever.create(File userLibDir,
String jobClassName,
String[] programArgs,
Configuration configuration)
Creates a
PackageProgramRetrieverImpl with the given parameters. |
static JobGraph |
PackagedProgramUtils.createJobGraph(PackagedProgram packagedProgram,
Configuration configuration,
int defaultParallelism,
boolean suppressOutput)
|
static JobGraph |
PackagedProgramUtils.createJobGraph(PackagedProgram packagedProgram,
Configuration configuration,
int defaultParallelism,
JobID jobID,
boolean suppressOutput)
|
static PerJobMiniClusterFactory |
PerJobMiniClusterFactory.createWithFactory(Configuration configuration,
java.util.function.Function<? super MiniClusterConfiguration,? extends MiniCluster> miniClusterFactory) |
static Pipeline |
PackagedProgramUtils.getPipelineFromProgram(PackagedProgram program,
Configuration configuration,
int parallelism,
boolean suppressOutput) |
static void |
ContextEnvironment.setAsContext(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
static void |
StreamContextEnvironment.setAsContext(PipelineExecutorServiceLoader executorServiceLoader,
Configuration clusterConfiguration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
PackagedProgram.Builder |
PackagedProgram.Builder.setConfiguration(Configuration configuration) |
Constructor and Description |
---|
ContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
MiniClusterClient(Configuration configuration,
MiniCluster miniCluster) |
OptimizerPlanEnvironment(Configuration configuration,
ClassLoader userClassloader,
int parallelism) |
StreamContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
StreamContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration clusterConfiguration,
Configuration configuration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout,
boolean programConfigEnabled,
Collection<String> programConfigWildcards) |
StreamPlanEnvironment(Configuration configuration,
ClassLoader userClassLoader,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
Configuration |
RestClusterClient.getFlinkConfiguration() |
Modifier and Type | Method and Description |
---|---|
static RestClusterClientConfiguration |
RestClusterClientConfiguration.fromConfiguration(Configuration config) |
Constructor and Description |
---|
RestClusterClient(Configuration config,
T clusterId) |
RestClusterClient(Configuration config,
T clusterId,
ClientHighAvailabilityServicesFactory factory) |
Modifier and Type | Class and Description |
---|---|
class |
DelegatingConfiguration
A configuration that manages a subset of keys with a common prefix from a given configuration.
|
class |
UnmodifiableConfiguration
Unmodifiable version of the Configuration class.
|
Modifier and Type | Method and Description |
---|---|
Configuration |
Configuration.clone() |
Configuration |
DelegatingConfiguration.clone() |
static Configuration |
ConfigurationUtils.createConfiguration(Properties properties)
Creates a new
Configuration from the given Properties . |
static Configuration |
Configuration.fromMap(Map<String,String> map)
Creates a new configuration that is initialized with the options of the given map.
|
static Configuration |
GlobalConfiguration.loadConfiguration()
Loads the global configuration from the environment.
|
static Configuration |
GlobalConfiguration.loadConfiguration(Configuration dynamicProperties)
Loads the global configuration and adds the given dynamic properties configuration.
|
static Configuration |
GlobalConfiguration.loadConfiguration(String configDir)
Loads the configuration files from the specified directory.
|
static Configuration |
GlobalConfiguration.loadConfiguration(String configDir,
Configuration dynamicProperties)
Loads the configuration files from the specified directory.
|
<T> Configuration |
Configuration.set(ConfigOption<T> option,
T value) |
<T> Configuration |
DelegatingConfiguration.set(ConfigOption<T> option,
T value) |
Modifier and Type | Method and Description |
---|---|
void |
UnmodifiableConfiguration.addAll(Configuration other) |
void |
Configuration.addAll(Configuration other) |
void |
DelegatingConfiguration.addAll(Configuration other) |
void |
UnmodifiableConfiguration.addAll(Configuration other,
String prefix) |
void |
Configuration.addAll(Configuration other,
String prefix)
Adds all entries from the given configuration into this configuration.
|
void |
DelegatingConfiguration.addAll(Configuration other,
String prefix) |
static MetricOptions.JobStatusMetricsSettings |
MetricOptions.JobStatusMetricsSettings.fromConfiguration(Configuration configuration) |
static String[] |
CoreOptions.getPluginParentFirstLoaderPatterns(Configuration config) |
static Map<String,String> |
ConfigurationUtils.getPrefixedKeyValuePairs(String prefix,
Configuration configuration)
Extract and parse Flink configuration properties with a given name prefix and return the
result as a Map.
|
static File |
ConfigurationUtils.getRandomTempDirectory(Configuration configuration)
Picks a temporary directory randomly from the given configuration.
|
static JobManagerOptions.SchedulerType |
ClusterOptions.getSchedulerType(Configuration configuration) |
static Time |
ConfigurationUtils.getStandaloneClusterStartupPeriodTime(Configuration configuration) |
static Optional<Time> |
ConfigurationUtils.getSystemResourceMetricsProbingInterval(Configuration configuration) |
static boolean |
ClusterOptions.isAdaptiveSchedulerEnabled(Configuration configuration) |
static boolean |
ClusterOptions.isFineGrainedResourceManagementEnabled(Configuration configuration) |
static boolean |
AkkaOptions.isForceRpcInvocationSerializationEnabled(Configuration config) |
static boolean |
SecurityOptions.isInternalSSLEnabled(Configuration sslConfig)
Checks whether SSL for internal communication (rpc, data transport, blob server) is enabled.
|
static boolean |
SecurityOptions.isRestSSLAuthenticationEnabled(Configuration sslConfig)
Checks whether mutual SSL authentication for the external REST endpoint is enabled.
|
static boolean |
SecurityOptions.isRestSSLEnabled(Configuration sslConfig)
Checks whether SSL for the external REST endpoint is enabled.
|
static Configuration |
GlobalConfiguration.loadConfiguration(Configuration dynamicProperties)
Loads the global configuration and adds the given dynamic properties configuration.
|
static Configuration |
GlobalConfiguration.loadConfiguration(String configDir,
Configuration dynamicProperties)
Loads the configuration files from the specified directory.
|
static String[] |
ConfigurationUtils.parseLocalStateDirectories(Configuration configuration)
Extracts the local state directories as defined by
CheckpointingOptions.LOCAL_RECOVERY_TASK_MANAGER_STATE_ROOT_DIRS . |
static String[] |
ConfigurationUtils.parseTempDirectories(Configuration configuration)
Extracts the task manager directories for temporary files as defined by
CoreOptions.TMP_DIRS . |
Constructor and Description |
---|
Configuration(Configuration other)
Creates a new configuration with the copy of the given configuration.
|
DelegatingConfiguration(Configuration backingConfig,
String prefix)
Creates a new delegating configuration which stores its key/value pairs in the given
configuration using the specifies key prefix.
|
UnmodifiableConfiguration(Configuration config)
Creates a new UnmodifiableConfiguration, which holds a copy of the given configuration that
cannot be altered.
|
Modifier and Type | Field and Description |
---|---|
protected Configuration |
SourceReaderBase.config
The raw configurations that may be used by subclasses.
|
Modifier and Type | Method and Description |
---|---|
BulkFormat.Reader<T> |
FileRecordFormatAdapter.createReader(Configuration config,
FileSourceSplit split)
Deprecated.
|
BulkFormat.Reader<T> |
StreamFormatAdapter.createReader(Configuration config,
FileSourceSplit split) |
BulkFormat.Reader<T> |
FileRecordFormatAdapter.restoreReader(Configuration config,
FileSourceSplit split)
Deprecated.
|
BulkFormat.Reader<T> |
StreamFormatAdapter.restoreReader(Configuration config,
FileSourceSplit split) |
Constructor and Description |
---|
FileSourceReader(SourceReaderContext readerContext,
BulkFormat<T,SplitT> readerFormat,
Configuration config) |
Modifier and Type | Method and Description |
---|---|
abstract StreamFormat.Reader<T> |
SimpleStreamFormat.createReader(Configuration config,
FSDataInputStream stream)
Creates a new reader.
|
TextLineInputFormat.Reader |
TextLineInputFormat.createReader(Configuration config,
FSDataInputStream stream) |
StreamFormat.Reader<T> |
SimpleStreamFormat.createReader(Configuration config,
FSDataInputStream stream,
long fileLen,
long splitEnd) |
StreamFormat.Reader<T> |
StreamFormat.createReader(Configuration config,
FSDataInputStream stream,
long fileLen,
long splitEnd)
Creates a new reader to read in this format.
|
FileRecordFormat.Reader<T> |
FileRecordFormat.createReader(Configuration config,
Path filePath,
long splitOffset,
long splitLength)
Deprecated.
Creates a new reader to read in this format.
|
BulkFormat.Reader<T> |
BulkFormat.createReader(Configuration config,
SplitT split)
Creates a new reader that reads from the
split's path starting
at the FileSourceSplit.offset() split's offset} and reads length bytes after the offset. |
StreamFormat.Reader<T> |
SimpleStreamFormat.restoreReader(Configuration config,
FSDataInputStream stream,
long restoredOffset,
long fileLen,
long splitEnd) |
StreamFormat.Reader<T> |
StreamFormat.restoreReader(Configuration config,
FSDataInputStream stream,
long restoredOffset,
long fileLen,
long splitEnd)
Restores a reader from a checkpointed position.
|
FileRecordFormat.Reader<T> |
FileRecordFormat.restoreReader(Configuration config,
Path filePath,
long restoredOffset,
long splitOffset,
long splitLength)
Deprecated.
Restores a reader from a checkpointed position.
|
BulkFormat.Reader<T> |
BulkFormat.restoreReader(Configuration config,
SplitT split)
Creates a new reader that reads from
split.path() starting at offset and
reads until length bytes after the offset. |
Modifier and Type | Method and Description |
---|---|
void |
FileSystemOutputFormat.configure(Configuration parameters) |
org.apache.flink.connector.file.table.DeserializationSchemaAdapter.Reader |
DeserializationSchemaAdapter.createReader(Configuration config,
FileSourceSplit split) |
BulkFormat.Reader<T> |
LimitableBulkFormat.createReader(Configuration config,
SplitT split) |
org.apache.flink.connector.file.table.DeserializationSchemaAdapter.Reader |
DeserializationSchemaAdapter.restoreReader(Configuration config,
FileSourceSplit split) |
BulkFormat.Reader<T> |
LimitableBulkFormat.restoreReader(Configuration config,
SplitT split) |
Constructor and Description |
---|
Context(Configuration conf,
OutputFormatFactory<T> factory) |
Modifier and Type | Method and Description |
---|---|
static PartitionCommitTrigger |
PartitionCommitTrigger.create(boolean isRestored,
OperatorStateStore stateStore,
Configuration conf,
ClassLoader cl,
List<String> partitionKeys,
ProcessingTimeService procTimeService) |
static PartitionCommitPredicate |
PartitionCommitPredicate.create(Configuration conf,
ClassLoader cl,
List<String> partitionKeys) |
static PartitionCommitPredicate |
PartitionCommitPredicate.createPartitionTimeCommitPredicate(Configuration conf,
ClassLoader cl,
List<String> partitionKeys) |
static PartitionCommitPredicate |
PartitionCommitPredicate.createProcTimeCommitPredicate(Configuration conf) |
static DataStreamSink<?> |
StreamingSink.sink(ProviderContext providerContext,
DataStream<PartitionCommitInfo> writer,
Path locationPath,
ObjectIdentifier identifier,
List<String> partitionKeys,
TableMetaStoreFactory msFactory,
FileSystemFactory fsFactory,
Configuration options)
Create a sink from file writer.
|
static <T> DataStream<PartitionCommitInfo> |
StreamingSink.writer(ProviderContext providerContext,
DataStream<T> inputStream,
long bucketCheckInterval,
StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> bucketsBuilder,
int parallelism,
List<String> partitionKeys,
Configuration conf)
Create a file writer by input stream.
|
Constructor and Description |
---|
PartitionCommitter(Path locationPath,
ObjectIdentifier tableIdentifier,
List<String> partitionKeys,
TableMetaStoreFactory metaStoreFactory,
FileSystemFactory fsFactory,
Configuration conf) |
PartitionTimeCommitPredicate(Configuration conf,
ClassLoader cl,
List<String> partitionKeys) |
ProcTimeCommitPredicate(Configuration conf) |
StreamingFileWriter(long bucketCheckInterval,
StreamingFileSink.BucketsBuilder<IN,String,? extends StreamingFileSink.BucketsBuilder<IN,String,?>> bucketsBuilder,
List<String> partitionKeys,
Configuration conf) |
Modifier and Type | Method and Description |
---|---|
Configuration |
CompactContext.getConfig() |
Configuration |
CompactContext.CompactContextImpl.getConfig() |
Modifier and Type | Method and Description |
---|---|
static CompactContext |
CompactContext.create(Configuration config,
FileSystem fileSystem,
String partition,
Path path) |
Modifier and Type | Method and Description |
---|---|
void |
HBaseSinkFunction.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractTableInputFormat.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractTableInputFormat.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcInputFormat.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcOutputFormat.configure(Configuration parameters) |
void |
GenericJdbcSinkFunction.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcRowDataInputFormat.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcXaSinkFunction.open(Configuration configuration) |
Constructor and Description |
---|
KafkaSourceReader(FutureCompletingBlockingQueue<RecordsWithSplitIds<org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]>>> elementsQueue,
KafkaSourceFetcherManager kafkaSourceFetcherManager,
RecordEmitter<org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]>,T,KafkaPartitionSplitState> recordEmitter,
Configuration config,
SourceReaderContext context,
KafkaSourceReaderMetrics kafkaSourceReaderMetrics) |
Modifier and Type | Class and Description |
---|---|
class |
PulsarConfiguration
An unmodifiable
Configuration for Pulsar. |
Modifier and Type | Method and Description |
---|---|
void |
PulsarConfigBuilder.set(Configuration config)
Fill in a set of configs which shouldn't be duplicated.
|
Modifier and Type | Method and Description |
---|---|
<T extends PulsarConfiguration> |
PulsarConfigBuilder.build(PulsarConfigValidator validator,
java.util.function.Function<Configuration,T> constructor)
Validate the current config instance and return a unmodifiable configuration.
|
Constructor and Description |
---|
PulsarConfiguration(Configuration config)
Creates a new PulsarConfiguration, which holds a copy of the given configuration that can't
be altered.
|
Modifier and Type | Method and Description |
---|---|
PulsarSinkBuilder<IN> |
PulsarSinkBuilder.setConfig(Configuration config)
Set arbitrary properties for the PulsarSink and Pulsar Producer.
|
Modifier and Type | Class and Description |
---|---|
class |
SinkConfiguration
The configured class for pulsar sink.
|
Constructor and Description |
---|
SinkConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
PulsarSourceBuilder<OUT> |
PulsarSourceBuilder.setConfig(Configuration config)
Set arbitrary properties for the PulsarSource and Pulsar Consumer.
|
Modifier and Type | Class and Description |
---|---|
class |
SourceConfiguration
The configuration class for pulsar source.
|
Constructor and Description |
---|
SourceConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
default void |
RangeGenerator.open(Configuration configuration,
SourceConfiguration sourceConfiguration)
Deprecated.
Use
RangeGenerator.open(SourceConfiguration) instead. |
Constructor and Description |
---|
PulsarFetcherManagerBase(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue,
java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier,
Configuration configuration)
Creates a new SplitFetcherManager with multiple I/O threads.
|
PulsarOrderedFetcherManager(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue,
java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier,
Configuration configuration) |
PulsarUnorderedFetcherManager(FutureCompletingBlockingQueue<RecordsWithSplitIds<PulsarMessage<T>>> elementsQueue,
java.util.function.Supplier<SplitReader<PulsarMessage<T>,PulsarPartitionSplit>> splitReaderSupplier,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
Configuration |
FlinkContainersSettings.getFlinkConfig()
Gets flink configuration.
|
Modifier and Type | Method and Description |
---|---|
static FlinkContainersSettings |
FlinkContainersSettings.basedOn(Configuration config)
FlinkContainersConfig based on provided Flink configuration. |
<T> FlinkContainersSettings.Builder |
FlinkContainersSettings.Builder.basedOn(Configuration config)
Merges the provided
config with the default config, potentially overwriting the
defaults in case of collisions. |
<T> FlinkContainersSettings.Builder |
FlinkContainersSettings.Builder.fullConfiguration(Configuration config)
Sets the
flinkConfiguration value to config and returns a reference to
this Builder enabling method chaining. |
FlinkImageBuilder |
FlinkImageBuilder.setConfiguration(Configuration conf)
Sets Flink configuration.
|
Constructor and Description |
---|
FlinkContainerTestEnvironment(Configuration clusterConfiguration,
int numTaskManagers,
int numSlotsPerTaskManager,
Collection<String> jarPaths) |
FlinkContainerTestEnvironment(Configuration clusterConfiguration,
int numTaskManagers,
int numSlotsPerTaskManager,
String... jarPaths) |
Constructor and Description |
---|
MetricQuerier(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
Configuration |
TestingReaderContext.getConfiguration() |
Constructor and Description |
---|
TestingReaderContext(Configuration config,
SourceReaderMetricGroup metricGroup) |
Constructor and Description |
---|
HiveContinuousPartitionFetcherContext(ObjectPath tablePath,
HiveShim hiveShim,
JobConfWrapper confWrapper,
List<String> partitionKeys,
DataType[] fieldTypes,
String[] fieldNames,
Configuration configuration,
String defaultPartitionName) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
HivePartitionFetcherContextBase.configuration |
Modifier and Type | Method and Description |
---|---|
void |
HiveTableInputFormat.configure(Configuration parameters) |
void |
HiveTableFileInputFormat.configure(Configuration parameters) |
BulkFormat.Reader<RowData> |
HiveInputFormat.createReader(Configuration config,
HiveSourceSplit split) |
BulkFormat.Reader<RowData> |
HiveInputFormat.restoreReader(Configuration config,
HiveSourceSplit split) |
Constructor and Description |
---|
HivePartitionFetcherContextBase(ObjectPath tablePath,
HiveShim hiveShim,
JobConfWrapper confWrapper,
List<String> partitionKeys,
DataType[] fieldTypes,
String[] fieldNames,
Configuration configuration,
String defaultPartitionName) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<JobClient> |
PipelineExecutor.execute(Pipeline pipeline,
Configuration configuration,
ClassLoader userCodeClassloader)
|
PipelineExecutor |
PipelineExecutorFactory.getExecutor(Configuration configuration)
Instantiates an
PipelineExecutor compatible with the provided configuration. |
PipelineExecutorFactory |
DefaultExecutorServiceLoader.getExecutorFactory(Configuration configuration) |
PipelineExecutorFactory |
PipelineExecutorServiceLoader.getExecutorFactory(Configuration configuration)
Loads the
PipelineExecutorFactory which is compatible with the provided
configuration. |
CompletableFuture<Void> |
CacheSupportedPipelineExecutor.invalidateClusterDataset(AbstractID clusterDatasetId,
Configuration configuration,
ClassLoader userCodeClassloader)
Invalidate the cluster dataset with the given id.
|
boolean |
PipelineExecutorFactory.isCompatibleWith(Configuration configuration)
Returns
true if this factory is compatible with the options in the provided
configuration, false otherwise. |
CompletableFuture<Set<AbstractID>> |
CacheSupportedPipelineExecutor.listCompletedClusterDatasetIds(Configuration configuration,
ClassLoader userCodeClassloader)
Return a set of ids of the completed cluster dataset.
|
Modifier and Type | Method and Description |
---|---|
void |
PluginFileSystemFactory.configure(Configuration config) |
void |
ConnectionLimitingFactory.configure(Configuration config) |
static FileSystemFactory |
ConnectionLimitingFactory.decorateIfLimited(FileSystemFactory factory,
String scheme,
Configuration config)
Decorates the given factory for a
ConnectionLimitingFactory , if the given
configuration configured connection limiting for the given file system scheme. |
static LimitedConnectionsFileSystem.ConnectionLimitingSettings |
LimitedConnectionsFileSystem.ConnectionLimitingSettings.fromConfig(Configuration config,
String fsScheme)
Parses and returns the settings for connection limiting, for the file system with the
given file system scheme.
|
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 |
---|---|
default void |
Plugin.configure(Configuration config)
Optional method for plugins to pick up settings from the configuration.
|
static PluginManager |
PluginUtils.createPluginManagerFromRootFolder(Configuration configuration) |
static PluginConfig |
PluginConfig.fromConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static void |
FlinkSecurityManager.setFromConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
KMeans.SelectNearestCenter.open(Configuration parameters)
Reads the centroid values from a broadcast variable into a collection.
|
Modifier and Type | Method and Description |
---|---|
void |
FileCopyTaskInputFormat.configure(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
void |
EmptyFieldsCountAccumulator.EmptyFieldFilter.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
ExternalResourceDriver |
GPUDriverFactory.createExternalResourceDriver(Configuration config) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.formats.avro.AbstractAvroBulkFormat.AvroReader |
AbstractAvroBulkFormat.createReader(Configuration config,
SplitT split) |
org.apache.flink.formats.avro.AbstractAvroBulkFormat.AvroReader |
AbstractAvroBulkFormat.restoreReader(Configuration config,
SplitT split) |
Modifier and Type | Method and Description |
---|---|
StreamFormat.Reader<T> |
CsvReaderFormat.createReader(Configuration config,
FSDataInputStream stream) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.formats.parquet.ParquetVectorizedInputFormat.ParquetReader |
ParquetVectorizedInputFormat.createReader(Configuration config,
SplitT split) |
protected int |
ParquetVectorizedInputFormat.numBatchesToCirculate(Configuration config) |
protected int |
ParquetColumnarRowInputFormat.numBatchesToCirculate(Configuration config) |
org.apache.flink.formats.parquet.ParquetVectorizedInputFormat.ParquetReader |
ParquetVectorizedInputFormat.restoreReader(Configuration config,
SplitT split) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractAzureFSFactory.configure(Configuration config) |
Modifier and Type | Method and Description |
---|---|
void |
GSFileSystemFactory.configure(Configuration flinkConfig) |
Constructor and Description |
---|
GSFileSystemOptions(Configuration flinkConfig)
Constructs an options instance.
|
Modifier and Type | Method and Description |
---|---|
static Configuration |
ConfigUtils.getHadoopConfiguration(Configuration flinkConfig,
ConfigUtils.ConfigContext configContext)
Loads the Hadoop configuration, by loading from a Hadoop conf dir (if one exists) and then
overlaying properties derived from the Flink config.
|
Modifier and Type | Method and Description |
---|---|
void |
OSSFileSystemFactory.configure(Configuration config) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractS3FileSystemFactory.configure(Configuration config) |
Modifier and Type | Method and Description |
---|---|
void |
HadoopMapFunction.open(Configuration parameters) |
void |
HadoopReduceCombineFunction.open(Configuration parameters) |
void |
HadoopReduceFunction.open(Configuration parameters) |
Modifier and Type | Method and Description |
---|---|
KubernetesClusterDescriptor |
KubernetesClusterClientFactory.createClusterDescriptor(Configuration configuration) |
String |
KubernetesClusterClientFactory.getClusterId(Configuration configuration) |
boolean |
KubernetesClusterClientFactory.isCompatibleWith(Configuration configuration) |
Constructor and Description |
---|
KubernetesClusterDescriptor(Configuration flinkConfig,
FlinkKubeClient client) |
KubernetesResourceManagerDriver(Configuration flinkConfig,
FlinkKubeClient flinkKubeClient,
KubernetesResourceManagerDriverConfiguration configuration) |
Constructor and Description |
---|
KubernetesSessionCli(Configuration configuration,
ClusterClientServiceLoader clusterClientServiceLoader,
String configDir) |
KubernetesSessionCli(Configuration configuration,
String configDir) |
Modifier and Type | Method and Description |
---|---|
static KubernetesDeploymentTarget |
KubernetesDeploymentTarget.fromConfig(Configuration configuration) |
Constructor and Description |
---|
KubernetesLeaderElectionConfiguration(String configMapName,
String lockIdentity,
Configuration config) |
Modifier and Type | Method and Description |
---|---|
WorkerResourceSpec |
KubernetesWorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
protected DispatcherResourceManagerComponentFactory |
KubernetesSessionClusterEntrypoint.createDispatcherResourceManagerComponentFactory(Configuration configuration) |
protected ResourceManagerDriver<KubernetesWorkerNode> |
KubernetesResourceManagerFactory.createResourceManagerDriver(Configuration configuration,
String webInterfaceUrl,
String rpcAddress) |
protected ResourceManagerRuntimeServicesConfiguration |
KubernetesResourceManagerFactory.createResourceManagerRuntimeServicesConfiguration(Configuration configuration) |
Constructor and Description |
---|
KubernetesSessionClusterEntrypoint(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
PipelineExecutor |
KubernetesSessionClusterExecutorFactory.getExecutor(Configuration configuration) |
boolean |
KubernetesSessionClusterExecutorFactory.isCompatibleWith(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
HighAvailabilityServices |
KubernetesHaServicesFactory.createHAServices(Configuration configuration,
Executor executor) |
HighAvailabilityServices |
KubernetesMultipleComponentLeaderElectionHaServicesFactory.createHAServices(Configuration configuration,
Executor executor) |
static KubernetesCheckpointRecoveryFactory |
KubernetesCheckpointRecoveryFactory.withLeadershipValidation(FlinkKubeClient kubeClient,
Configuration configuration,
Executor executor,
String clusterId,
java.util.function.Function<JobID,String> function,
String lockIdentity) |
static KubernetesCheckpointRecoveryFactory |
KubernetesCheckpointRecoveryFactory.withoutLeadershipValidation(FlinkKubeClient kubeClient,
Configuration configuration,
Executor executor,
String clusterId,
java.util.function.Function<JobID,String> function) |
Modifier and Type | Method and Description |
---|---|
FlinkKubeClient |
FlinkKubeClientFactory.fromConfiguration(Configuration flinkConfig,
String useCase)
Create a Flink Kubernetes client with the given configuration.
|
Constructor and Description |
---|
Fabric8FlinkKubeClient(Configuration flinkConfig,
io.fabric8.kubernetes.client.NamespacedKubernetesClient client,
ExecutorService executorService) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractKubernetesParameters.flinkConfig |
Modifier and Type | Method and Description |
---|---|
Configuration |
AbstractKubernetesParameters.getFlinkConfiguration() |
Constructor and Description |
---|
AbstractKubernetesParameters(Configuration flinkConfig) |
KubernetesJobManagerParameters(Configuration flinkConfig,
ClusterSpecification clusterSpecification) |
KubernetesTaskManagerParameters(Configuration flinkConfig,
String podName,
String dynamicProperties,
String jvmMemOptsEnv,
ContaineredTaskManagerParameters containeredTaskManagerParameters,
Map<String,String> taskManagerExternalResourceConfigKeys,
Set<String> blockedNodes) |
Modifier and Type | Method and Description |
---|---|
static void |
KubernetesUtils.checkAndUpdatePortConfigOption(Configuration flinkConfig,
ConfigOption<String> port,
int fallbackPort)
Check whether the port config option is a fixed port.
|
static List<File> |
KubernetesUtils.checkJarFileForApplicationMode(Configuration configuration) |
static CompletedCheckpointStore |
KubernetesUtils.createCompletedCheckpointStore(Configuration configuration,
FlinkKubeClient kubeClient,
Executor executor,
String configMapName,
String lockIdentity,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
RestoreMode restoreMode)
Create a
DefaultCompletedCheckpointStore with KubernetesStateHandleStore . |
static KubernetesStateHandleStore<JobGraph> |
KubernetesUtils.createJobGraphStateHandleStore(Configuration configuration,
FlinkKubeClient flinkKubeClient,
String configMapName,
String lockIdentity)
Create a
KubernetesStateHandleStore which storing JobGraph . |
static JobGraphStore |
KubernetesUtils.createJobGraphStore(Configuration configuration,
FlinkKubeClient flinkKubeClient,
String configMapName,
String lockIdentity)
Create a
DefaultJobGraphStore with NoOpJobGraphStoreWatcher . |
static boolean |
KubernetesUtils.isHostNetwork(Configuration configuration)
Checks if hostNetwork is enabled.
|
static Integer |
KubernetesUtils.parsePort(Configuration flinkConfig,
ConfigOption<String> port)
Parse a valid port for the config option.
|
static <T> String |
KubernetesUtils.resolveUserDefinedValue(Configuration flinkConfig,
ConfigOption<T> configOption,
String valueOfConfigOptionOrDefault,
String valueOfPodTemplate,
String fieldDescription)
Resolve the user defined value with the precedence.
|
Constructor and Description |
---|
Optimizer(Configuration config)
Creates a new optimizer instance.
|
Optimizer(CostEstimator estimator,
Configuration config)
Creates a new optimizer instance.
|
Optimizer(DataStatistics stats,
Configuration config)
Creates a new optimizer instance that uses the statistics object to determine properties
about the input.
|
Optimizer(DataStatistics stats,
CostEstimator estimator,
Configuration config)
Creates a new optimizer instance that uses the statistics object to determine properties
about the input.
|
Constructor and Description |
---|
JobGraphGenerator(Configuration config) |
Modifier and Type | Method and Description |
---|---|
AbstractOrcFileInputFormat.OrcVectorizedReader<T,BatchT> |
AbstractOrcFileInputFormat.createReader(Configuration config,
SplitT split) |
AbstractOrcFileInputFormat.OrcVectorizedReader<T,BatchT> |
AbstractOrcFileInputFormat.restoreReader(Configuration config,
SplitT split) |
Modifier and Type | Method and Description |
---|---|
Configuration |
PythonConfig.toConfiguration() |
Modifier and Type | Method and Description |
---|---|
static Configuration |
PythonDependencyUtils.configurePythonDependencies(List<Tuple2<String,DistributedCache.DistributedCacheEntry>> cachedFiles,
ReadableConfig config)
Adds python dependencies to registered cache file list according to given configuration and
returns a new configuration which contains the metadata of the registered python
dependencies.
|
static Configuration |
PythonConfigUtil.extractPythonConfiguration(List<Tuple2<String,DistributedCache.DistributedCacheEntry>> cachedFiles,
ReadableConfig config)
Extract the configurations which is used in the Python operators.
|
static Configuration |
PythonConfigUtil.getEnvironmentConfig(StreamExecutionEnvironment env) |
static Configuration |
PythonDependencyUtils.parsePythonDependencyConfiguration(org.apache.commons.cli.CommandLine commandLine) |
Modifier and Type | Method and Description |
---|---|
static void |
PythonDependencyUtils.merge(Configuration config,
Configuration pythonConfiguration) |
void |
PythonConnectorUtils.RowRowMapper.open(Configuration parameters) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractBlobCache.blobClientConfig
Configuration for the blob client like ssl parameters required to connect to the blob server.
|
Modifier and Type | Method and Description |
---|---|
static BlobCacheService |
BlobUtils.createBlobCacheService(Configuration configuration,
Reference<File> fallbackStorageDirectory,
BlobView blobView,
InetSocketAddress serverAddress)
Creates the
BlobCacheService from the given configuration, fallback storage
directory, blob view and blob server address. |
static BlobServer |
BlobUtils.createBlobServer(Configuration configuration,
Reference<File> fallbackStorageDirectory,
BlobStore blobStore)
Creates the
BlobServer from the given configuration, fallback storage directory and
blob store. |
static BlobStoreService |
BlobUtils.createBlobStoreFromConfig(Configuration config)
Creates a BlobStore based on the parameters set in the configuration.
|
static List<PermanentBlobKey> |
BlobClient.uploadFiles(InetSocketAddress serverAddress,
Configuration clientConfig,
JobID jobId,
List<Path> files)
Uploads the JAR files to the
PermanentBlobService of the BlobServer at the
given address with HA as configured. |
Constructor and Description |
---|
AbstractBlobCache(Configuration blobClientConfig,
Reference<File> storageDir,
BlobView blobView,
org.slf4j.Logger logger,
InetSocketAddress serverAddress) |
BlobCacheService(Configuration blobClientConfig,
File storageDir,
BlobView blobView,
InetSocketAddress serverAddress) |
BlobCacheService(Configuration blobClientConfig,
Reference<File> storageDir,
BlobView blobView,
InetSocketAddress serverAddress)
Instantiates a new BLOB cache.
|
BlobClient(InetSocketAddress serverAddress,
Configuration clientConfig)
Instantiates a new BLOB client.
|
BlobServer(Configuration config,
File storageDir,
BlobStore blobStore) |
BlobServer(Configuration config,
Reference<File> storageDir,
BlobStore blobStore)
Instantiates a new BLOB server and binds it to a free network port.
|
PermanentBlobCache(Configuration blobClientConfig,
File storageDir,
BlobView blobView,
InetSocketAddress serverAddress) |
PermanentBlobCache(Configuration blobClientConfig,
File storageDir,
BlobView blobView,
InetSocketAddress serverAddress,
BlobCacheSizeTracker blobCacheSizeTracker) |
PermanentBlobCache(Configuration blobClientConfig,
Reference<File> storageDir,
BlobView blobView,
InetSocketAddress serverAddress)
Instantiates a new cache for permanent BLOBs which are also available in an HA store.
|
PermanentBlobCache(Configuration blobClientConfig,
Reference<File> storageDir,
BlobView blobView,
InetSocketAddress serverAddress,
BlobCacheSizeTracker blobCacheSizeTracker) |
TransientBlobCache(Configuration blobClientConfig,
File storageDir,
InetSocketAddress serverAddress) |
TransientBlobCache(Configuration blobClientConfig,
Reference<File> storageDir,
InetSocketAddress serverAddress)
Instantiates a new BLOB cache.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
BlocklistUtils.isBlocklistEnabled(Configuration configuration) |
static BlocklistHandler.Factory |
BlocklistUtils.loadBlocklistHandlerFactory(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static void |
Checkpoints.disposeSavepoint(String pointer,
Configuration configuration,
ClassLoader classLoader,
org.slf4j.Logger logger) |
static int |
DefaultCompletedCheckpointStoreUtils.getMaximumNumberOfRetainedCheckpoints(Configuration config,
org.slf4j.Logger logger)
Extracts maximum number of retained checkpoints configuration from the passed
Configuration . |
static CheckpointStorage |
Checkpoints.loadCheckpointStorage(Configuration configuration,
ClassLoader classLoader,
org.slf4j.Logger logger) |
static StateBackend |
Checkpoints.loadStateBackend(Configuration configuration,
ClassLoader classLoader,
org.slf4j.Logger logger) |
Constructor and Description |
---|
ZooKeeperCheckpointRecoveryFactory(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
Configuration config,
Executor executor) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
BootstrapTools.cloneConfiguration(Configuration configuration)
Clones the given configuration and resets instance specific config options.
|
static Configuration |
TaskExecutorProcessUtils.getConfigurationMapLegacyTaskManagerHeapSizeToConfigOption(Configuration configuration,
ConfigOption<MemorySize> configOption) |
static Configuration |
BootstrapTools.parseDynamicProperties(org.apache.commons.cli.CommandLine cmd)
Parse the dynamic properties (passed on the command line).
|
Modifier and Type | Method and Description |
---|---|
static Configuration |
BootstrapTools.cloneConfiguration(Configuration configuration)
Clones the given configuration and resets instance specific config options.
|
static ContaineredTaskManagerParameters |
ContaineredTaskManagerParameters.create(Configuration config,
TaskExecutorProcessSpec taskExecutorProcessSpec)
Computes the parameters to be used to start a TaskManager Java process.
|
static Configuration |
TaskExecutorProcessUtils.getConfigurationMapLegacyTaskManagerHeapSizeToConfigOption(Configuration configuration,
ConfigOption<MemorySize> configOption) |
static CPUResource |
TaskExecutorProcessUtils.getCpuCoresWithFallback(Configuration config,
double fallback) |
static double |
TaskExecutorProcessUtils.getCpuCoresWithFallbackConfigOption(Configuration config,
ConfigOption<Double> fallbackOption) |
static String |
BootstrapTools.getDynamicPropertiesAsString(Configuration baseConfig,
Configuration targetConfig)
Get dynamic properties based on two Flink configurations.
|
static String |
BootstrapTools.getTaskManagerShellCommand(Configuration flinkConfig,
ContaineredTaskManagerParameters tmParams,
String configDirectory,
String logDirectory,
boolean hasLogback,
boolean hasLog4j,
boolean hasKrb5,
Class<?> mainClass,
String mainArgs)
Generates the shell command to start a task manager.
|
static TaskExecutorProcessSpecBuilder |
TaskExecutorProcessUtils.newProcessSpecBuilder(Configuration config) |
static TaskExecutorProcessSpec |
TaskExecutorProcessUtils.processSpecFromConfig(Configuration config) |
static TaskExecutorProcessSpec |
TaskExecutorProcessUtils.processSpecFromWorkerResourceSpec(Configuration config,
WorkerResourceSpec workerResourceSpec) |
static void |
BootstrapTools.substituteDeprecatedConfigKey(Configuration config,
String deprecated,
String designated)
Sets the value of a new config key to the value of a deprecated config key.
|
static void |
BootstrapTools.substituteDeprecatedConfigPrefix(Configuration config,
String deprecatedPrefix,
String designatedPrefix)
Sets the value of a new config key to the value of a deprecated config key.
|
static void |
BootstrapTools.updateTmpDirectoriesInConfiguration(Configuration configuration,
String defaultDirs)
Set temporary configuration directories if necessary.
|
static void |
BootstrapTools.writeConfiguration(Configuration cfg,
File file)
Writes a Flink YAML config file from a Flink Configuration object.
|
Modifier and Type | Method and Description |
---|---|
Configuration |
PartialDispatcherServices.getConfiguration() |
Configuration |
DispatcherServices.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
static HistoryServerArchivist |
HistoryServerArchivist.createHistoryServerArchivist(Configuration configuration,
JsonArchivist jsonArchivist,
Executor ioExecutor) |
JobManagerRunner |
JobMasterServiceLeadershipRunnerFactory.createJobManagerRunner(JobGraph jobGraph,
Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
JobManagerSharedServices jobManagerServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler,
long initializationTimestamp) |
JobManagerRunner |
JobManagerRunnerFactory.createJobManagerRunner(JobGraph jobGraph,
Configuration configuration,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
JobManagerSharedServices jobManagerServices,
JobManagerJobMetricGroupFactory jobManagerJobMetricGroupFactory,
FatalErrorHandler fatalErrorHandler,
long initializationTimestamp) |
Constructor and Description |
---|
DispatcherRestEndpoint(GatewayRetriever<DispatcherGateway> leaderRetriever,
Configuration clusterConfiguration,
RestHandlerConfiguration restConfiguration,
GatewayRetriever<ResourceManagerGateway> resourceManagerRetriever,
TransientBlobService transientBlobService,
ScheduledExecutorService executor,
MetricFetcher metricFetcher,
LeaderElectionService leaderElectionService,
ExecutionGraphCache executionGraphCache,
FatalErrorHandler fatalErrorHandler) |
PartialDispatcherServices(Configuration configuration,
HighAvailabilityServices highAvailabilityServices,
GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
JobManagerMetricGroupFactory jobManagerMetricGroupFactory,
ExecutionGraphInfoStore executionGraphInfoStore,
FatalErrorHandler fatalErrorHandler,
HistoryServerArchivist historyServerArchivist,
String metricQueryServiceAddress,
Executor ioExecutor,
DispatcherOperationCaches operationCaches) |
Modifier and Type | Method and Description |
---|---|
JobManagerRunner |
CleanupRunnerFactory.create(JobResult jobResult,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Configuration configuration,
Executor cleanupExecutor) |
CheckpointResourcesCleanupRunner |
CheckpointResourcesCleanupRunnerFactory.create(JobResult jobResult,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Configuration configuration,
Executor cleanupExecutor) |
RetryStrategy |
CleanupRetryStrategyFactory.createRetryStrategy(Configuration configuration)
Creates the
RetryStrategy instance based on the passed Configuration . |
Constructor and Description |
---|
CheckpointResourcesCleanupRunner(JobResult jobResult,
CheckpointRecoveryFactory checkpointRecoveryFactory,
SharedStateRegistryFactory sharedStateRegistryFactory,
Configuration jobManagerConfiguration,
Executor cleanupExecutor,
long initializationTimestamp) |
Modifier and Type | Method and Description |
---|---|
Configuration |
DynamicParametersConfigurationParserFactory.createResult(org.apache.commons.cli.CommandLine commandLine) |
protected static Configuration |
ClusterEntrypoint.loadConfiguration(EntrypointClusterConfiguration entrypointClusterConfiguration) |
Modifier and Type | Method and Description |
---|---|
static void |
ClusterEntrypointUtils.configureUncaughtExceptionHandler(Configuration config)
Sets the uncaught exception handler for current thread based on configuration.
|
protected abstract DispatcherResourceManagerComponentFactory |
ClusterEntrypoint.createDispatcherResourceManagerComponentFactory(Configuration configuration) |
protected DefaultDispatcherResourceManagerComponentFactory |
StandaloneSessionClusterEntrypoint.createDispatcherResourceManagerComponentFactory(Configuration configuration) |
protected HighAvailabilityServices |
ClusterEntrypoint.createHaServices(Configuration configuration,
Executor executor,
RpcSystemUtils rpcSystemUtils) |
protected HeartbeatServices |
ClusterEntrypoint.createHeartbeatServices(Configuration configuration) |
static DeterminismEnvelope<WorkingDirectory> |
ClusterEntrypointUtils.createJobManagerWorkingDirectory(Configuration configuration,
DeterminismEnvelope<ResourceID> envelopedResourceId)
Creates the working directory for the JobManager process.
|
protected MetricRegistryImpl |
ClusterEntrypoint.createMetricRegistry(Configuration configuration,
PluginManager pluginManager,
RpcSystemUtils rpcSystemUtils) |
protected ExecutionGraphInfoStore |
JobClusterEntrypoint.createSerializableExecutionGraphStore(Configuration configuration,
ScheduledExecutor scheduledExecutor)
Deprecated.
|
protected ExecutionGraphInfoStore |
SessionClusterEntrypoint.createSerializableExecutionGraphStore(Configuration configuration,
ScheduledExecutor scheduledExecutor) |
protected abstract ExecutionGraphInfoStore |
ClusterEntrypoint.createSerializableExecutionGraphStore(Configuration configuration,
ScheduledExecutor scheduledExecutor) |
static DeterminismEnvelope<WorkingDirectory> |
ClusterEntrypointUtils.createTaskManagerWorkingDirectory(Configuration configuration,
DeterminismEnvelope<ResourceID> envelopedResourceId)
Creates the working directory for the TaskManager process.
|
static File |
ClusterEntrypointUtils.generateJobManagerWorkingDirectoryFile(Configuration configuration,
ResourceID resourceId)
Generates the working directory
File for the JobManager process. |
static File |
ClusterEntrypointUtils.generateTaskManagerWorkingDirectoryFile(Configuration configuration,
ResourceID resourceId)
Generates the working directory
File for the TaskManager process. |
static File |
ClusterEntrypointUtils.generateWorkingDirectoryFile(Configuration configuration,
Optional<ConfigOption<String>> workingDirOption,
String workingDirectoryName)
Generate the working directory from the given configuration.
|
static int |
ClusterEntrypointUtils.getPoolSize(Configuration config)
Gets and verify the io-executor pool size based on configuration.
|
protected String |
ClusterEntrypoint.getRPCPortRange(Configuration configuration)
Returns the port range for the common
RpcService . |
protected void |
ClusterEntrypoint.initializeServices(Configuration configuration,
PluginManager pluginManager) |
Constructor and Description |
---|
ClusterEntrypoint(Configuration configuration) |
JobClusterEntrypoint(Configuration configuration)
Deprecated.
|
SessionClusterEntrypoint(Configuration configuration) |
StandaloneSessionClusterEntrypoint(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
DispatcherResourceManagerComponent |
DispatcherResourceManagerComponentFactory.create(Configuration configuration,
ResourceID resourceId,
Executor ioExecutor,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
MetricRegistry metricRegistry,
ExecutionGraphInfoStore executionGraphInfoStore,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
DispatcherResourceManagerComponent |
DefaultDispatcherResourceManagerComponentFactory.create(Configuration configuration,
ResourceID resourceId,
Executor ioExecutor,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
MetricRegistry metricRegistry,
ExecutionGraphInfoStore executionGraphInfoStore,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
static FileJobGraphRetriever |
FileJobGraphRetriever.createFrom(Configuration configuration,
File usrLibDir) |
JobGraph |
FileJobGraphRetriever.retrieveJobGraph(Configuration configuration) |
JobGraph |
JobGraphRetriever.retrieveJobGraph(Configuration configuration)
Retrieve the
JobGraph . |
Modifier and Type | Method and Description |
---|---|
Configuration |
Environment.getJobConfiguration()
Returns the job-wide configuration object that was attached to the JobGraph.
|
Configuration |
Environment.getTaskConfiguration()
Returns the task-wide configuration object, originally attached to the job vertex.
|
Modifier and Type | Method and Description |
---|---|
Configuration |
DefaultExecutionGraph.getJobConfiguration() |
Configuration |
JobInformation.getJobConfiguration() |
Configuration |
ExecutionGraph.getJobConfiguration() |
Configuration |
TaskInformation.getTaskConfiguration() |
Modifier and Type | Method and Description |
---|---|
static DefaultExecutionGraph |
DefaultExecutionGraphBuilder.buildGraph(JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
ClassLoader classLoader,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
Time rpcTimeout,
BlobWriter blobWriter,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
ExecutionDeploymentListener executionDeploymentListener,
ExecutionStateUpdateListener executionStateUpdateListener,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore,
java.util.function.Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory,
boolean isDynamicGraph,
ExecutionJobVertex.Factory executionJobVertexFactory) |
Constructor and Description |
---|
JobInformation(JobID jobId,
String jobName,
SerializedValue<ExecutionConfig> serializedExecutionConfig,
Configuration jobConfiguration,
Collection<PermanentBlobKey> requiredJarFileBlobKeys,
Collection<URL> requiredClasspathURLs) |
TaskInformation(JobVertexID jobVertexId,
String taskName,
int numberOfSubtasks,
int maxNumberOfSubtasks,
String invokableClassName,
Configuration taskConfiguration) |
Modifier and Type | Method and Description |
---|---|
static PartitionGroupReleaseStrategy.Factory |
PartitionGroupReleaseStrategyFactoryLoader.loadPartitionGroupReleaseStrategyFactory(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static ExternalResourceInfoProvider |
ExternalResourceUtils.createStaticExternalResourceInfoProviderFromConfig(Configuration configuration,
PluginManager pluginManager)
Instantiate
StaticExternalResourceInfoProvider for all of enabled external resources. |
static Map<String,String> |
ExternalResourceUtils.getExternalResourceConfigurationKeys(Configuration config,
String suffix)
Get the external resource configuration keys map, indexed by the resource name.
|
static Collection<ExternalResource> |
ExternalResourceUtils.getExternalResourcesCollection(Configuration config)
Get the collection of all enabled external resources.
|
Modifier and Type | Method and Description |
---|---|
void |
HadoopFsFactory.configure(Configuration config) |
Modifier and Type | Method and Description |
---|---|
static HeartbeatServices |
HeartbeatServices.fromConfiguration(Configuration configuration)
Creates an HeartbeatServices instance from a
Configuration . |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractHaServices.configuration
The runtime configuration.
|
Modifier and Type | Method and Description |
---|---|
ClientHighAvailabilityServices |
ClientHighAvailabilityServicesFactory.create(Configuration configuration,
FatalErrorHandler fatalErrorHandler)
Creates a
ClientHighAvailabilityServices instance. |
ClientHighAvailabilityServices |
DefaultClientHighAvailabilityServicesFactory.create(Configuration configuration,
FatalErrorHandler fatalErrorHandler) |
static HighAvailabilityServices |
HighAvailabilityServicesUtils.createAvailableOrEmbeddedServices(Configuration config,
Executor executor,
FatalErrorHandler fatalErrorHandler) |
static ClientHighAvailabilityServices |
HighAvailabilityServicesUtils.createClientHAService(Configuration configuration,
FatalErrorHandler fatalErrorHandler) |
default ClientHighAvailabilityServices |
HighAvailabilityServicesFactory.createClientHAServices(Configuration configuration)
Create a
ClientHighAvailabilityServices instance. |
HighAvailabilityServices |
HighAvailabilityServicesFactory.createHAServices(Configuration configuration,
Executor executor)
Creates a
HighAvailabilityServices instance. |
static HighAvailabilityServices |
HighAvailabilityServicesUtils.createHighAvailabilityServices(Configuration configuration,
Executor executor,
AddressResolution addressResolution,
RpcSystemUtils rpcSystemUtils,
FatalErrorHandler fatalErrorHandler) |
static FileSystemJobResultStore |
FileSystemJobResultStore.fromConfiguration(Configuration config) |
static Path |
HighAvailabilityServicesUtils.getClusterHighAvailableStoragePath(Configuration configuration)
Gets the cluster high available storage path from the provided configuration.
|
static Tuple2<String,Integer> |
HighAvailabilityServicesUtils.getJobManagerAddress(Configuration configuration)
Returns the JobManager's hostname and port extracted from the given
Configuration . |
static String |
HighAvailabilityServicesUtils.getWebMonitorAddress(Configuration configuration,
AddressResolution resolution)
Get address of web monitor from configuration.
|
Constructor and Description |
---|
AbstractHaServices(Configuration config,
Executor ioExecutor,
BlobStoreService blobStoreService,
JobResultStore jobResultStore) |
Constructor and Description |
---|
AbstractZooKeeperHaServices(CuratorFrameworkWithUnhandledErrorListener curatorFrameworkWrapper,
Executor executor,
Configuration configuration,
BlobStoreService blobStoreService) |
ZooKeeperClientHAServices(CuratorFrameworkWithUnhandledErrorListener curatorFrameworkWrapper,
Configuration configuration) |
ZooKeeperMultipleComponentLeaderElectionHaServices(CuratorFrameworkWithUnhandledErrorListener curatorFrameworkWrapper,
Configuration config,
Executor ioExecutor,
BlobStoreService blobStoreService,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
Configuration |
NettyConfig.getConfig() |
Modifier and Type | Method and Description |
---|---|
Optional<org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler> |
OutboundChannelHandlerFactory.createHandler(Configuration configuration)
Creates new instance of
ChannelHandler |
Optional<org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler> |
InboundChannelHandlerFactory.createHandler(Configuration configuration,
Map<String,String> responseHeaders)
Creates new instance of
ChannelHandler |
Constructor and Description |
---|
NettyConfig(InetAddress serverAddress,
int serverPort,
int memorySegmentSize,
int numberOfSlots,
Configuration config) |
Modifier and Type | Method and Description |
---|---|
Configuration |
JobVertex.getConfiguration()
Returns the vertex's configuration object which can be used to pass custom settings to the
task at runtime.
|
Configuration |
JobGraph.getJobConfiguration()
Returns the configuration object for this job.
|
Configuration |
InputOutputFormatContainer.getParameters(OperatorID operatorId) |
Modifier and Type | Method and Description |
---|---|
InputOutputFormatContainer |
InputOutputFormatContainer.addParameters(OperatorID operatorId,
Configuration parameters) |
static void |
SavepointRestoreSettings.toConfiguration(SavepointRestoreSettings savepointRestoreSettings,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
Configuration |
AbstractInvokable.getJobConfiguration()
Returns the job configuration object which was attached to the original
JobGraph . |
Configuration |
AbstractInvokable.getTaskConfiguration()
Returns the task configuration object which was attached to the original
JobVertex . |
Modifier and Type | Method and Description |
---|---|
static HighAvailabilityMode |
HighAvailabilityMode.fromConfig(Configuration config)
Return the configured
HighAvailabilityMode . |
static String |
JobManagerProcessUtils.generateJvmParametersStr(JobManagerProcessSpec processSpec,
Configuration configuration) |
static boolean |
HighAvailabilityMode.isHighAvailabilityModeActivated(Configuration configuration)
Returns true if the defined recovery mode supports high availability.
|
static JobManagerProcessSpec |
JobManagerProcessUtils.processSpecFromConfigWithNewOptionToInterpretLegacyHeap(Configuration config,
ConfigOption<MemorySize> newOptionToInterpretLegacyHeap) |
Modifier and Type | Method and Description |
---|---|
Configuration |
JobMasterConfiguration.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
SlotPoolServiceSchedulerFactory.createScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration configuration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
BlocklistOperations blocklistOperations)
Creates a
SchedulerNG . |
SchedulerNG |
DefaultSlotPoolServiceSchedulerFactory.createScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration configuration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
BlocklistOperations blocklistOperations) |
static JobMasterConfiguration |
JobMasterConfiguration.fromConfiguration(Configuration configuration) |
static JobManagerSharedServices |
JobManagerSharedServices.fromConfiguration(Configuration config,
BlobServer blobServer,
FatalErrorHandler fatalErrorHandler) |
static DefaultSlotPoolServiceSchedulerFactory |
DefaultSlotPoolServiceSchedulerFactory.fromConfiguration(Configuration configuration,
JobType jobType) |
Constructor and Description |
---|
JobMasterConfiguration(Time rpcTimeout,
Time slotRequestTimeout,
String tmpDirectory,
RetryingRegistrationConfiguration retryingRegistrationConfiguration,
Configuration configuration) |
MiniDispatcherRestEndpoint(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Configuration clusterConfiguration,
RestHandlerConfiguration restConfiguration,
GatewayRetriever<ResourceManagerGateway> resourceManagerRetriever,
TransientBlobService transientBlobService,
ScheduledExecutorService executor,
MetricFetcher metricFetcher,
LeaderElectionService leaderElectionService,
ExecutionGraphCache executionGraphCache,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
static MetricRegistryConfiguration |
MetricRegistryConfiguration.fromConfiguration(Configuration configuration,
long maximumFrameSize)
Create a metric registry configuration object from the given
Configuration . |
static List<ReporterSetup> |
ReporterSetup.fromConfiguration(Configuration configuration,
PluginManager pluginManager) |
Modifier and Type | Method and Description |
---|---|
static MetricFilter |
DefaultMetricFilter.fromConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static ScopeFormats |
ScopeFormats.fromConfig(Configuration config)
Creates the scope formats as defined in the given configuration.
|
Modifier and Type | Method and Description |
---|---|
static RpcService |
MetricUtils.startLocalMetricsRpcService(Configuration configuration,
RpcSystem rpcSystem) |
static RpcService |
MetricUtils.startRemoteMetricsRpcService(Configuration configuration,
String externalAddress,
String bindAddress,
RpcSystem rpcSystem) |
Modifier and Type | Method and Description |
---|---|
Configuration |
MiniCluster.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
protected Collection<? extends DispatcherResourceManagerComponent> |
MiniCluster.createDispatcherResourceManagerComponents(Configuration configuration,
MiniCluster.RpcServiceFactory rpcServiceFactory,
BlobServer blobServer,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
MetricRegistry metricRegistry,
MetricQueryServiceRetriever metricQueryServiceRetriever,
FatalErrorHandler fatalErrorHandler) |
protected HighAvailabilityServices |
MiniCluster.createHighAvailabilityServices(Configuration configuration,
Executor executor) |
protected RpcService |
MiniCluster.createLocalRpcService(Configuration configuration,
RpcSystem rpcSystem)
Factory method to instantiate the local RPC service.
|
protected MetricRegistryImpl |
MiniCluster.createMetricRegistry(Configuration config,
long maximumMessageSizeInBytes)
Factory method to create the metric registry for the mini cluster.
|
protected RpcService |
MiniCluster.createRemoteRpcService(Configuration configuration,
String bindAddress,
int bindPort,
RpcSystem rpcSystem)
Factory method to instantiate the remote RPC service.
|
protected RpcService |
MiniCluster.createRemoteRpcService(Configuration configuration,
String externalAddress,
String externalPortRange,
String bindAddress,
RpcSystem rpcSystem)
Factory method to instantiate the remote RPC service.
|
MiniClusterConfiguration.Builder |
MiniClusterConfiguration.Builder.setConfiguration(Configuration configuration1) |
Constructor and Description |
---|
MiniClusterConfiguration(Configuration configuration,
int numTaskManagers,
RpcServiceSharing rpcServiceSharing,
String commonBindAddress,
MiniCluster.HaServices haServices) |
Modifier and Type | Method and Description |
---|---|
static SSLHandlerFactory |
SSLUtils.createInternalClientSSLEngineFactory(Configuration config)
Creates a SSLEngineFactory to be used by internal communication client endpoints.
|
static SSLHandlerFactory |
SSLUtils.createInternalServerSSLEngineFactory(Configuration config)
Creates a SSLEngineFactory to be used by internal communication server endpoints.
|
static SSLHandlerFactory |
SSLUtils.createRestClientSSLEngineFactory(Configuration config)
Creates a
SSLHandlerFactory to be used by the REST Clients. |
static org.apache.flink.shaded.netty4.io.netty.handler.ssl.SslContext |
SSLUtils.createRestNettySSLContext(Configuration config,
boolean clientMode,
org.apache.flink.shaded.netty4.io.netty.handler.ssl.ClientAuth clientAuth,
org.apache.flink.shaded.netty4.io.netty.handler.ssl.SslProvider provider)
Creates an SSL context for the external REST SSL.
|
static SSLHandlerFactory |
SSLUtils.createRestServerSSLEngineFactory(Configuration config)
Creates a
SSLHandlerFactory to be used by the REST Servers. |
static SSLContext |
SSLUtils.createRestSSLContext(Configuration config,
boolean clientMode)
Creates an SSL context for clients against the external REST endpoint.
|
static SocketFactory |
SSLUtils.createSSLClientSocketFactory(Configuration config)
Creates a factory for SSL Client Sockets from the given configuration.
|
static ServerSocketFactory |
SSLUtils.createSSLServerSocketFactory(Configuration config)
Creates a factory for SSL Server Sockets from the given configuration.
|
Modifier and Type | Method and Description |
---|---|
static void |
BatchTask.openUserCode(Function stub,
Configuration parameters)
Opens the given stub using its
RichFunction.open(Configuration) method. |
Modifier and Type | Method and Description |
---|---|
ExternalSorterBuilder<T> |
ExternalSorterBuilder.withCombiner(GroupCombineFunction<T,T> combineFunction,
Configuration udfConfig) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
TaskConfig.config |
Modifier and Type | Method and Description |
---|---|
Configuration |
TaskConfig.getConfiguration()
Gets the configuration that holds the actual values encoded.
|
Configuration |
TaskConfig.getStubParameters() |
Modifier and Type | Method and Description |
---|---|
void |
TaskConfig.setStubParameters(Configuration parameters) |
Constructor and Description |
---|
TaskConfig(Configuration config)
Creates a new Task Config that wraps the given configuration.
|
Modifier and Type | Method and Description |
---|---|
static RetryingRegistrationConfiguration |
RetryingRegistrationConfiguration.fromConfiguration(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
StandaloneResourceManagerFactory.getConfigurationWithoutMaxSlotNumberIfSet(Configuration configuration)
Get the configuration for standalone ResourceManager, overwrite invalid configs.
|
protected Configuration |
ResourceManagerFactory.getEffectiveConfigurationForResourceManager(Configuration configuration)
Configuration changes in this method will be visible to only
ResourceManager . |
protected Configuration |
ResourceManagerFactory.getEffectiveConfigurationForResourceManagerAndRuntimeServices(Configuration configuration)
Configuration changes in this method will be visible to both
ResourceManager and
ResourceManagerRuntimeServices . |
Configuration |
ResourceManagerProcessContext.getRmConfig() |
Modifier and Type | Method and Description |
---|---|
static ResourceManagerServiceImpl |
ResourceManagerServiceImpl.create(ResourceManagerFactory<?> resourceManagerFactory,
Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
MetricRegistry metricRegistry,
String hostname,
Executor ioExecutor) |
abstract WorkerResourceSpec |
WorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
WorkerResourceSpec |
ArbitraryWorkerResourceSpecFactory.createDefaultWorkerResourceSpec(Configuration configuration) |
protected abstract ResourceManager<T> |
ResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
UUID leaderSessionId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ResourceManagerRuntimeServices resourceManagerRuntimeServices,
Executor ioExecutor) |
protected ResourceManager<ResourceID> |
StandaloneResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
UUID leaderSessionId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ResourceManagerRuntimeServices resourceManagerRuntimeServices,
Executor ioExecutor) |
ResourceManagerProcessContext |
ResourceManagerFactory.createResourceManagerProcessContext(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
MetricRegistry metricRegistry,
String hostname,
Executor ioExecutor) |
protected abstract ResourceManagerRuntimeServicesConfiguration |
ResourceManagerFactory.createResourceManagerRuntimeServicesConfiguration(Configuration configuration) |
protected ResourceManagerRuntimeServicesConfiguration |
StandaloneResourceManagerFactory.createResourceManagerRuntimeServicesConfiguration(Configuration configuration) |
static ResourceManagerRuntimeServicesConfiguration |
ResourceManagerRuntimeServicesConfiguration.fromConfiguration(Configuration configuration,
WorkerResourceSpecFactory defaultWorkerResourceSpecFactory) |
static Configuration |
StandaloneResourceManagerFactory.getConfigurationWithoutMaxSlotNumberIfSet(Configuration configuration)
Get the configuration for standalone ResourceManager, overwrite invalid configs.
|
protected Configuration |
ResourceManagerFactory.getEffectiveConfigurationForResourceManager(Configuration configuration)
Configuration changes in this method will be visible to only
ResourceManager . |
protected Configuration |
ResourceManagerFactory.getEffectiveConfigurationForResourceManagerAndRuntimeServices(Configuration configuration)
Configuration changes in this method will be visible to both
ResourceManager and
ResourceManagerRuntimeServices . |
protected WorkerResourceSpec |
WorkerResourceSpecFactory.workerResourceSpecFromConfigAndCpu(Configuration configuration,
CPUResource cpuResource) |
Constructor and Description |
---|
ResourceManagerProcessContext(Configuration rmConfig,
ResourceID resourceId,
ResourceManagerRuntimeServicesConfiguration rmRuntimeServicesConfig,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
MetricRegistry metricRegistry,
String hostname,
Executor ioExecutor) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
AbstractResourceManagerDriver.flinkClientConfig |
protected Configuration |
AbstractResourceManagerDriver.flinkConfig |
protected Configuration |
ActiveResourceManager.flinkConfig |
Modifier and Type | Method and Description |
---|---|
protected Configuration |
ActiveResourceManagerFactory.getEffectiveConfigurationForResourceManager(Configuration configuration) |
protected Configuration |
ActiveResourceManagerFactory.getEffectiveConfigurationForResourceManagerAndRuntimeServices(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
ResourceManager<WorkerType> |
ActiveResourceManagerFactory.createResourceManager(Configuration configuration,
ResourceID resourceId,
RpcService rpcService,
UUID leaderSessionId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
FatalErrorHandler fatalErrorHandler,
ClusterInformation clusterInformation,
String webInterfaceUrl,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ResourceManagerRuntimeServices resourceManagerRuntimeServices,
Executor ioExecutor) |
protected abstract ResourceManagerDriver<WorkerType> |
ActiveResourceManagerFactory.createResourceManagerDriver(Configuration configuration,
String webInterfaceUrl,
String rpcAddress) |
static ThresholdMeter |
ActiveResourceManagerFactory.createStartWorkerFailureRater(Configuration configuration) |
protected Configuration |
ActiveResourceManagerFactory.getEffectiveConfigurationForResourceManager(Configuration configuration) |
protected Configuration |
ActiveResourceManagerFactory.getEffectiveConfigurationForResourceManagerAndRuntimeServices(Configuration configuration) |
Constructor and Description |
---|
AbstractResourceManagerDriver(Configuration flinkConfig,
Configuration flinkClientConfig) |
ActiveResourceManager(ResourceManagerDriver<WorkerType> resourceManagerDriver,
Configuration flinkConfig,
RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
BlocklistHandler.Factory blocklistHandlerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
ThresholdMeter startWorkerFailureRater,
java.time.Duration retryInterval,
java.time.Duration workerRegistrationTimeout,
java.time.Duration previousWorkerRecoverTimeout,
Executor ioExecutor) |
Modifier and Type | Method and Description |
---|---|
static SlotManagerConfiguration |
SlotManagerConfiguration.fromConfiguration(Configuration configuration,
WorkerResourceSpec defaultWorkerResourceSpec) |
Constructor and Description |
---|
RestClient(Configuration configuration,
Executor executor) |
RestServerEndpoint(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static RestHandlerConfiguration |
RestHandlerConfiguration.fromConfiguration(Configuration configuration) |
Constructor and Description |
---|
ClusterConfigHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<EmptyRequestBody,ConfigurationInfo,EmptyMessageParameters> messageHeaders,
Configuration configuration) |
Constructor and Description |
---|
JobManagerJobConfigurationHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<EmptyRequestBody,ConfigurationInfo,JobMessageParameters> messageHeaders,
Configuration configuration) |
JobSubmitHandler(GatewayRetriever<? extends DispatcherGateway> leaderRetriever,
Time timeout,
Map<String,String> headers,
Executor executor,
Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static <T extends RestfulGateway> |
MetricFetcherImpl.fromConfiguration(Configuration configuration,
MetricQueryServiceRetriever metricQueryServiceGatewayRetriever,
GatewayRetriever<T> dispatcherGatewayRetriever,
ExecutorService executor) |
Modifier and Type | Method and Description |
---|---|
static ConfigurationInfo |
ConfigurationInfo.from(Configuration config) |
Modifier and Type | Method and Description |
---|---|
static RpcService |
RpcUtils.createRemoteRpcService(RpcSystem rpcSystem,
Configuration configuration,
String externalAddress,
String externalPortRange,
String bindAddress,
Optional<Integer> bindPort)
Convenient shortcut for constructing a remote RPC Service that takes care of checking for
null and empty optionals.
|
long |
RpcSystemUtils.getMaximumMessageSizeInBytes(Configuration config)
Returns the maximum number of bytes that an RPC message may carry according to the given
configuration.
|
String |
RpcSystemUtils.getRpcUrl(String hostname,
int port,
String endpointName,
AddressResolution addressResolution,
Configuration config)
Constructs an RPC URL for the given parameters, that can be used to connect to the targeted
RpcService.
|
static RpcSystem |
RpcSystem.load(Configuration config)
Loads the RpcSystem.
|
RpcSystem |
RpcSystemLoader.loadRpcSystem(Configuration config) |
RpcSystem.RpcServiceBuilder |
RpcSystem.localServiceBuilder(Configuration configuration)
Returns a builder for an
RpcService that is only reachable from the local machine. |
RpcSystem.RpcServiceBuilder |
RpcSystem.remoteServiceBuilder(Configuration configuration,
String externalAddress,
String externalPortRange)
Returns a builder for an
RpcService that is reachable from other machines. |
Modifier and Type | Method and Description |
---|---|
Configuration |
AkkaRpcServiceConfiguration.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
static long |
AkkaRpcServiceUtils.extractMaximumFramesize(Configuration configuration) |
static AkkaRpcServiceConfiguration |
AkkaRpcServiceConfiguration.fromConfiguration(Configuration configuration) |
static RpcSystem.ForkJoinExecutorConfiguration |
AkkaBootstrapTools.getForkJoinExecutorConfiguration(Configuration configuration) |
long |
AkkaRpcSystem.getMaximumMessageSizeInBytes(Configuration config) |
String |
AkkaRpcSystem.getRpcUrl(String hostname,
int port,
String endpointName,
AddressResolution addressResolution,
Configuration config) |
static String |
AkkaRpcServiceUtils.getRpcUrl(String hostname,
int port,
String endpointName,
AddressResolution addressResolution,
Configuration config) |
RpcSystem |
AkkaRpcSystemLoader.loadRpcSystem(Configuration config) |
RpcSystem.RpcServiceBuilder |
AkkaRpcSystem.localServiceBuilder(Configuration configuration) |
RpcSystem.RpcServiceBuilder |
AkkaRpcSystem.remoteServiceBuilder(Configuration configuration,
String externalAddress,
String externalPortRange) |
static akka.actor.ActorSystem |
AkkaBootstrapTools.startLocalActorSystem(Configuration configuration,
String actorSystemName,
org.slf4j.Logger logger,
com.typesafe.config.Config actorSystemExecutorConfiguration,
com.typesafe.config.Config customConfig)
Starts a local Actor System.
|
static akka.actor.ActorSystem |
AkkaBootstrapTools.startRemoteActorSystem(Configuration configuration,
String externalAddress,
String externalPortRange,
org.slf4j.Logger logger)
Starts a remote ActorSystem at given address and specific port range.
|
static akka.actor.ActorSystem |
AkkaBootstrapTools.startRemoteActorSystem(Configuration configuration,
String actorSystemName,
String externalAddress,
String externalPortRange,
String bindAddress,
Optional<Integer> bindPort,
org.slf4j.Logger logger,
com.typesafe.config.Config actorSystemExecutorConfiguration,
com.typesafe.config.Config customConfig)
Starts a remote ActorSystem at given address and specific port range.
|
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
SchedulerUtils.createCompletedCheckpointStoreIfCheckpointingIsEnabled(JobGraph jobGraph,
Configuration configuration,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Executor ioExecutor,
org.slf4j.Logger log) |
SchedulerNG |
DefaultSchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
BlocklistOperations blocklistOperations) |
SchedulerNG |
SchedulerNGFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
BlocklistOperations blocklistOperations) |
Constructor and Description |
---|
DefaultExecutionGraphFactory(Configuration configuration,
ClassLoader userCodeClassLoader,
ExecutionDeploymentTracker executionDeploymentTracker,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
BlobWriter blobWriter,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker jobMasterPartitionTracker) |
DefaultExecutionGraphFactory(Configuration configuration,
ClassLoader userCodeClassLoader,
ExecutionDeploymentTracker executionDeploymentTracker,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
BlobWriter blobWriter,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker jobMasterPartitionTracker,
boolean isDynamicGraph,
ExecutionJobVertex.Factory executionJobVertexFactory) |
DefaultScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
java.util.function.Consumer<ComponentMainThreadExecutor> startUpAction,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
ExecutionOperations executionOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismStore vertexParallelismStore,
ExecutionDeployer.Factory executionDeployerFactory) |
SchedulerBase(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
ExecutionVertexVersioner executionVertexVersioner,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
VertexParallelismStore vertexParallelismStore) |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
AdaptiveSchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
BlocklistOperations blocklistOperations) |
Constructor and Description |
---|
AdaptiveScheduler(JobGraph jobGraph,
Configuration configuration,
DeclarativeSlotPool declarativeSlotPool,
SlotAllocator slotAllocator,
Executor ioExecutor,
ClassLoader userCodeClassLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
java.time.Duration initialResourceAllocationTimeout,
java.time.Duration resourceStabilizationTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory) |
Constructor and Description |
---|
ReactiveScaleUpController(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
SchedulerNG |
AdaptiveBatchSchedulerFactory.createInstance(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
SlotPoolService slotPoolService,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
BlocklistOperations blocklistOperations) |
Constructor and Description |
---|
AdaptiveBatchScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
java.util.function.Consumer<ComponentMainThreadExecutor> startUpAction,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
ExecutionOperations executionOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismDecider vertexParallelismDecider,
int defaultMaxParallelism) |
SpeculativeScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
java.util.function.Consumer<ComponentMainThreadExecutor> startUpAction,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
ExecutionOperations executionOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismDecider vertexParallelismDecider,
int defaultMaxParallelism,
BlocklistOperations blocklistOperations) |
Constructor and Description |
---|
ExecutionTimeBasedSlowTaskDetector(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
Configuration |
SecurityConfiguration.getFlinkConfig() |
Constructor and Description |
---|
SecurityConfiguration(Configuration flinkConf)
Create a security configuration from the global configuration.
|
SecurityConfiguration(Configuration flinkConf,
List<String> securityContextFactory,
List<String> securityModuleFactories)
Create a security configuration from the global configuration.
|
Modifier and Type | Method and Description |
---|---|
static DelegationTokenManager |
KerberosDelegationTokenManagerFactory.create(ClassLoader classLoader,
Configuration configuration,
ScheduledExecutor scheduledExecutor,
ExecutorService ioExecutor) |
void |
DelegationTokenProvider.init(Configuration configuration)
Called by
DelegationTokenManager to initialize provider after construction. |
void |
HadoopFSDelegationTokenProvider.init(Configuration configuration) |
Constructor and Description |
---|
KerberosDelegationTokenManager(Configuration configuration,
ScheduledExecutor scheduledExecutor,
ExecutorService ioExecutor) |
KerberosDelegationTokenManager(Configuration configuration,
ScheduledExecutor scheduledExecutor,
ExecutorService ioExecutor,
KerberosLoginProvider kerberosLoginProvider) |
KerberosLoginProvider(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
Configuration |
ShuffleMasterContextImpl.getConfiguration() |
Configuration |
ShuffleMasterContext.getConfiguration() |
Configuration |
ShuffleEnvironmentContext.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
static ShuffleServiceFactory<?,?,?> |
ShuffleServiceLoader.loadShuffleServiceFactory(Configuration configuration) |
Constructor and Description |
---|
NettyShuffleMaster(Configuration conf) |
ShuffleEnvironmentContext(Configuration configuration,
ResourceID taskExecutorResourceId,
MemorySize networkMemorySize,
boolean localCommunicationOnly,
InetAddress hostAddress,
int numberOfSlots,
String[] tmpDirPaths,
TaskEventPublisher eventPublisher,
MetricGroup parentMetricGroup,
Executor ioExecutor) |
ShuffleMasterContextImpl(Configuration configuration,
FatalErrorHandler fatalErrorHandler) |
Modifier and Type | Method and Description |
---|---|
static StateBackend |
StateBackendLoader.fromApplicationOrConfigOrDefault(StateBackend fromApplication,
TernaryBoolean isChangelogStateBackendEnableFromApplication,
Configuration config,
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, java.lang.ClassLoader, org.slf4j.Logger) when delegation is enabled. |
StateChangelogStorageView<?> |
TaskStateManager.getStateChangelogStorageView(Configuration configuration,
ChangelogStateHandle changelogStateHandle)
Returns the state changelog storage view of given
ChangelogStateHandle for this task. |
StateChangelogStorageView<?> |
TaskStateManagerImpl.getStateChangelogStorageView(Configuration configuration,
ChangelogStateHandle changelogStateHandle) |
static CheckpointStorage |
CheckpointStorageLoader.load(CheckpointStorage fromApplication,
Path defaultSavepointDirectory,
StateBackend configuredStateBackend,
Configuration config,
ClassLoader classLoader,
org.slf4j.Logger logger)
Loads the configured
CheckpointStorage for the job based on the following precedent
rules: |
TaskLocalStateStore |
TaskExecutorLocalStateStoresManager.localStateStoreForSubtask(JobID jobId,
AllocationID allocationID,
JobVertexID jobVertexID,
int subtaskIndex,
Configuration clusterConfiguration,
Configuration jobConfiguration) |
static boolean |
StateBackendLoader.stateBackendFromApplicationOrConfigOrDefaultUseManagedMemory(Configuration config,
Optional<Boolean> stateBackendFromApplicationUsesManagedMemory,
ClassLoader classLoader)
Checks whether state backend uses managed memory, without having to deserialize or load the
state backend.
|
StateChangelogStorage<?> |
TaskExecutorStateChangelogStoragesManager.stateChangelogStorageForJob(JobID jobId,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
StateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig)
Create the storage based on a configuration.
|
StateChangelogStorageView<?> |
StateChangelogStorageFactory.createStorageView(Configuration configuration)
Create the storage for recovery.
|
static StateChangelogStorage<?> |
StateChangelogStorageLoader.load(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
static StateChangelogStorageView<?> |
StateChangelogStorageLoader.loadFromStateHandle(Configuration configuration,
ChangelogStateHandle changelogStateHandle) |
Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
InMemoryStateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
StateChangelogStorageView<?> |
InMemoryStateChangelogStorageFactory.createStorageView(Configuration configuration) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
TaskExecutorResourceUtils.adjustForLocalExecution(Configuration config) |
Configuration |
TaskManagerServicesConfiguration.getConfiguration() |
Configuration |
TaskManagerConfiguration.getConfiguration() |
static Configuration |
TaskManagerRunner.loadConfiguration(String[] args) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
TaskExecutorResourceUtils.adjustForLocalExecution(Configuration config) |
static long |
TaskExecutorResourceUtils.calculateTotalFlinkMemoryFromComponents(Configuration config) |
static long |
TaskExecutorResourceUtils.calculateTotalProcessMemoryFromComponents(Configuration config) |
static TaskExecutorMemoryConfiguration |
TaskExecutorMemoryConfiguration.create(Configuration config)
Factory method for initializing a TaskExecutorMemoryConfiguration based on the passed
Configuration.
|
TaskManagerRunner.TaskExecutorService |
TaskManagerRunner.TaskExecutorServiceFactory.createTaskExecutor(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
BlobCacheService blobCacheService,
boolean localCommunicationOnly,
ExternalResourceInfoProvider externalResourceInfoProvider,
WorkingDirectory workingDirectory,
FatalErrorHandler fatalErrorHandler) |
static TaskManagerRunner.TaskExecutorService |
TaskManagerRunner.createTaskExecutorService(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
BlobCacheService blobCacheService,
boolean localCommunicationOnly,
ExternalResourceInfoProvider externalResourceInfoProvider,
WorkingDirectory workingDirectory,
FatalErrorHandler fatalErrorHandler) |
static QueryableStateConfiguration |
QueryableStateConfiguration.fromConfiguration(Configuration config)
Creates the
QueryableStateConfiguration from the given Configuration. |
static TaskManagerServicesConfiguration |
TaskManagerServicesConfiguration.fromConfiguration(Configuration configuration,
ResourceID resourceID,
String externalAddress,
boolean localCommunicationOnly,
TaskExecutorResourceSpec taskExecutorResourceSpec,
WorkingDirectory workingDirectory)
Utility method to extract TaskManager config parameters from the configuration and to sanity
check them.
|
static TaskManagerConfiguration |
TaskManagerConfiguration.fromConfiguration(Configuration configuration,
TaskExecutorResourceSpec taskExecutorResourceSpec,
String externalAddress,
File tmpWorkingDirectory) |
static TaskExecutorResourceSpec |
TaskExecutorResourceUtils.resourceSpecFromConfigForLocalExecution(Configuration config) |
static int |
TaskManagerRunner.runTaskManager(Configuration configuration,
PluginManager pluginManager) |
static void |
TaskManagerRunner.runTaskManagerProcessSecurely(Configuration configuration) |
static TaskExecutor |
TaskManagerRunner.startTaskManager(Configuration configuration,
ResourceID resourceID,
RpcService rpcService,
HighAvailabilityServices highAvailabilityServices,
HeartbeatServices heartbeatServices,
MetricRegistry metricRegistry,
TaskExecutorBlobService taskExecutorBlobService,
boolean localCommunicationOnly,
ExternalResourceInfoProvider externalResourceInfoProvider,
WorkingDirectory workingDirectory,
FatalErrorHandler fatalErrorHandler) |
Constructor and Description |
---|
TaskManagerConfiguration(int numberSlots,
ResourceProfile defaultSlotResourceProfile,
ResourceProfile totalResourceProfile,
String[] tmpDirectories,
Time rpcTimeout,
Time slotTimeout,
java.time.Duration maxRegistrationDuration,
Configuration configuration,
boolean exitJvmOnOutOfMemory,
String taskManagerLogPath,
String taskManagerStdoutPath,
String taskManagerLogDir,
String taskManagerExternalAddress,
File tmpWorkingDirectory,
RetryingRegistrationConfiguration retryingRegistrationConfiguration) |
TaskManagerRunner(Configuration configuration,
PluginManager pluginManager,
TaskManagerRunner.TaskExecutorServiceFactory taskExecutorServiceFactory) |
Modifier and Type | Method and Description |
---|---|
Configuration |
TaskManagerRuntimeInfo.getConfiguration()
Gets the configuration that the TaskManager was started with.
|
Configuration |
Task.getJobConfiguration() |
Configuration |
RuntimeEnvironment.getJobConfiguration() |
Configuration |
Task.getTaskConfiguration() |
Configuration |
RuntimeEnvironment.getTaskConfiguration() |
Modifier and Type | Method and Description |
---|---|
static NettyShuffleEnvironmentConfiguration |
NettyShuffleEnvironmentConfiguration.fromConfiguration(Configuration configuration,
MemorySize networkMemorySize,
boolean localTaskManagerCommunication,
InetAddress taskManagerAddress)
Utility method to extract network related parameters from the configuration and to sanity
check them.
|
static void |
MemoryLogger.startIfConfigured(org.slf4j.Logger logger,
Configuration configuration,
CompletableFuture<Void> taskManagerTerminationFuture) |
Constructor and Description |
---|
RuntimeEnvironment(JobID jobId,
JobVertexID jobVertexId,
ExecutionAttemptID executionId,
ExecutionConfig executionConfig,
TaskInfo taskInfo,
Configuration jobConfiguration,
Configuration taskConfiguration,
UserCodeClassLoader userCodeClassLoader,
MemoryManager memManager,
IOManager ioManager,
BroadcastVariableManager bcVarManager,
TaskStateManager taskStateManager,
GlobalAggregateManager aggregateManager,
AccumulatorRegistry accumulatorRegistry,
TaskKvStateRegistry kvStateRegistry,
InputSplitProvider splitProvider,
Map<String,Future<Path>> distCacheEntries,
ResultPartitionWriter[] writers,
IndexedInputGate[] inputGates,
TaskEventDispatcher taskEventDispatcher,
CheckpointResponder checkpointResponder,
TaskOperatorEventGateway operatorEventGateway,
TaskManagerRuntimeInfo taskManagerInfo,
TaskMetricGroup metrics,
Task containingTask,
ExternalResourceInfoProvider externalResourceInfoProvider) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
ConfigurationParserUtils.loadCommonConfiguration(String[] args,
String cmdLineSyntax)
Generate configuration from only the config file and dynamic properties.
|
Modifier and Type | Method and Description |
---|---|
static CompletedCheckpointStore |
ZooKeeperUtils.createCompletedCheckpoints(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
Configuration configuration,
int maxNumberOfCheckpointsToRetain,
SharedStateRegistryFactory sharedStateRegistryFactory,
Executor ioExecutor,
Executor executor,
RestoreMode restoreMode)
Creates a
DefaultCompletedCheckpointStore instance with ZooKeeperStateHandleStore . |
static <T extends Serializable> |
ZooKeeperUtils.createFileSystemStateStorage(Configuration configuration,
String prefix)
Creates a
FileSystemStateStorageHelper instance. |
static JobGraphStore |
ZooKeeperUtils.createJobGraphs(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
Configuration configuration)
Creates a
DefaultJobGraphStore instance with ZooKeeperStateHandleStore ,
ZooKeeperJobGraphStoreWatcher and ZooKeeperJobGraphStoreUtil . |
static ZooKeeperLeaderRetrievalDriverFactory |
ZooKeeperUtils.createLeaderRetrievalDriverFactory(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
String path,
Configuration configuration)
Creates a
LeaderRetrievalDriverFactory implemented by ZooKeeper. |
static DefaultLeaderRetrievalService |
ZooKeeperUtils.createLeaderRetrievalService(org.apache.flink.shaded.curator5.org.apache.curator.framework.CuratorFramework client,
String path,
Configuration configuration)
Creates a
DefaultLeaderRetrievalService instance with ZooKeeperLeaderRetrievalDriver . |
static ZooKeeperUtils.ZkClientACLMode |
ZooKeeperUtils.ZkClientACLMode.fromConfig(Configuration config)
Return the configured
ZooKeeperUtils.ZkClientACLMode . |
static Configuration |
HadoopUtils.getHadoopConfiguration(Configuration flinkConfiguration) |
static int |
ConfigurationParserUtils.getPageSize(Configuration configuration)
Parses the configuration to get the page size and validates the value.
|
static int |
ConfigurationParserUtils.getSlot(Configuration configuration)
Parses the configuration to get the number of slots and validates the value.
|
static String |
ZooKeeperUtils.getZooKeeperEnsemble(Configuration flinkConf)
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not
tolerate it).
|
static boolean |
ZooKeeperUtils.isZooKeeperRecoveryMode(Configuration flinkConf)
Returns whether
HighAvailabilityMode.ZOOKEEPER is configured. |
static SlotSelectionStrategy |
SlotSelectionStrategyUtils.selectSlotSelectionStrategy(JobType jobType,
Configuration configuration) |
void |
HadoopConfigLoader.setFlinkConfig(Configuration config) |
static CuratorFrameworkWithUnhandledErrorListener |
ZooKeeperUtils.startCuratorFramework(Configuration configuration,
FatalErrorHandler fatalErrorHandler)
Starts a
CuratorFramework instance and connects it to the given ZooKeeper quorum. |
Modifier and Type | Method and Description |
---|---|
static Configuration |
FlinkConfigLoader.loadConfiguration(String[] args) |
Modifier and Type | Method and Description |
---|---|
Configuration |
MemoryBackwardsCompatibilityUtils.getConfWithLegacyHeapSizeMappedToNewConfigOption(Configuration configuration,
ConfigOption<MemorySize> configOption) |
Modifier and Type | Method and Description |
---|---|
JobManagerFlinkMemory |
JobManagerFlinkMemoryUtils.deriveFromRequiredFineGrainedOptions(Configuration config) |
JobManagerFlinkMemory |
JobManagerFlinkMemoryUtils.deriveFromTotalFlinkMemory(Configuration config,
MemorySize totalFlinkMemorySize) |
Modifier and Type | Method and Description |
---|---|
TaskExecutorFlinkMemory |
TaskExecutorFlinkMemoryUtils.deriveFromRequiredFineGrainedOptions(Configuration config) |
TaskExecutorFlinkMemory |
TaskExecutorFlinkMemoryUtils.deriveFromTotalFlinkMemory(Configuration config,
MemorySize totalFlinkMemorySize) |
static MemorySize |
TaskExecutorFlinkMemoryUtils.getFrameworkHeapMemorySize(Configuration config) |
static MemorySize |
TaskExecutorFlinkMemoryUtils.getFrameworkOffHeapMemorySize(Configuration config) |
Modifier and Type | Field and Description |
---|---|
protected Configuration |
WebMonitorEndpoint.clusterConfiguration |
Modifier and Type | Method and Description |
---|---|
static WebMonitorUtils.LogFileLocation |
WebMonitorUtils.LogFileLocation.find(Configuration config)
Finds the Flink log directory using log.file Java property that is set during startup.
|
static |