Uses of Class
org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
-
-
Uses of TaskManagerJobMetricGroup in org.apache.flink.runtime.checkpoint.filemerging
Methods in org.apache.flink.runtime.checkpoint.filemerging with parameters of type TaskManagerJobMetricGroup Modifier and Type Method Description FileMergingSnapshotManagerBuilderFileMergingSnapshotManagerBuilder. setMetricGroup(TaskManagerJobMetricGroup metricGroup) -
Uses of TaskManagerJobMetricGroup in org.apache.flink.runtime.metrics.groups
Subclasses of TaskManagerJobMetricGroup in org.apache.flink.runtime.metrics.groups Modifier and Type Class Description static classUnregisteredMetricGroups.UnregisteredTaskManagerJobMetricGroupA safe drop-in replacement forTaskManagerJobMetricGroups.Methods in org.apache.flink.runtime.metrics.groups that return TaskManagerJobMetricGroup Modifier and Type Method Description TaskManagerJobMetricGroupTaskManagerMetricGroup. addJob(org.apache.flink.api.common.JobID jobId, String jobName)static TaskManagerJobMetricGroupUnregisteredMetricGroups. createUnregisteredTaskManagerJobMetricGroup()TaskManagerJobMetricGroupTaskManagerMetricGroup. getJobMetricsGroup(org.apache.flink.api.common.JobID jobId)TaskManagerJobMetricGroupTaskMetricGroup. parent() -
Uses of TaskManagerJobMetricGroup in org.apache.flink.runtime.metrics.scope
Methods in org.apache.flink.runtime.metrics.scope with parameters of type TaskManagerJobMetricGroup Modifier and Type Method Description String[]TaskScopeFormat. formatScope(TaskManagerJobMetricGroup parent, org.apache.flink.util.AbstractID vertexId, ExecutionAttemptID attemptId, String taskName, int subtask, int attemptNumber) -
Uses of TaskManagerJobMetricGroup in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type TaskManagerJobMetricGroup Modifier and Type Method Description FileMergingSnapshotManagerTaskExecutorFileMergingManager. fileMergingSnapshotManagerForTask(org.apache.flink.api.common.JobID jobId, ResourceID tmResourceId, ExecutionAttemptID executionAttemptID, org.apache.flink.configuration.Configuration clusterConfiguration, org.apache.flink.configuration.Configuration jobConfiguration, TaskManagerJobMetricGroup metricGroup)Initialize file merging snapshot manager for each job according configurations whenTaskExecutor.submitTask(org.apache.flink.runtime.deployment.TaskDeploymentDescriptor, org.apache.flink.runtime.jobmaster.JobMasterId, java.time.Duration).StateChangelogStorage<?>TaskExecutorStateChangelogStoragesManager. stateChangelogStorageForJob(org.apache.flink.api.common.JobID jobId, org.apache.flink.configuration.Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig) -
Uses of TaskManagerJobMetricGroup in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog with parameters of type TaskManagerJobMetricGroup Modifier and Type Method Description StateChangelogStorage<?>StateChangelogStorageFactory. createStorage(org.apache.flink.api.common.JobID jobID, org.apache.flink.configuration.Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)Create the storage based on a configuration.static StateChangelogStorage<?>StateChangelogStorageLoader. load(org.apache.flink.api.common.JobID jobID, org.apache.flink.configuration.Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig) -
Uses of TaskManagerJobMetricGroup in org.apache.flink.runtime.state.changelog.inmemory
Methods in org.apache.flink.runtime.state.changelog.inmemory with parameters of type TaskManagerJobMetricGroup Modifier and Type Method Description StateChangelogStorage<?>InMemoryStateChangelogStorageFactory. createStorage(org.apache.flink.api.common.JobID jobID, org.apache.flink.configuration.Configuration configuration, TaskManagerJobMetricGroup metricGroup, LocalRecoveryConfig localRecoveryConfig)
-