Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
FsStateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
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 |
---|---|
FileMergingSnapshotManagerBuilder |
FileMergingSnapshotManagerBuilder.setMetricGroup(TaskManagerJobMetricGroup metricGroup) |
Modifier and Type | Class and Description |
---|---|
static class |
UnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroup
A safe drop-in replacement for
TaskManagerJobMetricGroup s. |
Modifier and Type | Method and Description |
---|---|
TaskManagerJobMetricGroup |
TaskManagerMetricGroup.addJob(JobID jobId,
String jobName) |
static TaskManagerJobMetricGroup |
UnregisteredMetricGroups.createUnregisteredTaskManagerJobMetricGroup() |
TaskManagerJobMetricGroup |
TaskManagerMetricGroup.getJobMetricsGroup(JobID jobId) |
TaskManagerJobMetricGroup |
TaskMetricGroup.parent() |
Modifier and Type | Method and Description |
---|---|
String[] |
TaskScopeFormat.formatScope(TaskManagerJobMetricGroup parent,
AbstractID vertexId,
ExecutionAttemptID attemptId,
String taskName,
int subtask,
int attemptNumber) |
Modifier and Type | Method and Description |
---|---|
FileMergingSnapshotManager |
TaskExecutorFileMergingManager.fileMergingSnapshotManagerForTask(JobID jobId,
ResourceID tmResourceId,
ExecutionAttemptID executionAttemptID,
Configuration clusterConfiguration,
Configuration jobConfiguration,
TaskManagerJobMetricGroup metricGroup)
Initialize file merging snapshot manager for each job according configurations when
TaskExecutor.submitTask(org.apache.flink.runtime.deployment.TaskDeploymentDescriptor, org.apache.flink.runtime.jobmaster.JobMasterId, org.apache.flink.api.common.time.Time) . |
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.
|
static StateChangelogStorage<?> |
StateChangelogStorageLoader.load(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
StateChangelogStorage<?> |
InMemoryStateChangelogStorageFactory.createStorage(JobID jobID,
Configuration configuration,
TaskManagerJobMetricGroup metricGroup,
LocalRecoveryConfig localRecoveryConfig) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.