public class JobManagerJobMetricGroup extends JobMetricGroup
MetricGroup
representing everything belonging to
a specific job, running on the JobManager.jobId, jobName
registry
Constructor and Description |
---|
JobManagerJobMetricGroup(MetricRegistry registry,
JobManagerMetricGroup parent,
org.apache.flink.api.common.JobID jobId,
String jobName) |
JobManagerJobMetricGroup(MetricRegistry registry,
JobManagerMetricGroup parent,
JobManagerJobScopeFormat scopeFormat,
org.apache.flink.api.common.JobID jobId,
String jobName) |
Modifier and Type | Method and Description |
---|---|
JobManagerMetricGroup |
parent() |
protected Iterable<? extends ComponentMetricGroup> |
subComponents()
Gets all component metric groups that are contained in this component metric group.
|
jobId, jobName
close
addGroup, addGroup, addMetric, counter, counter, counter, counter, gauge, gauge, getMetricIdentifier, getMetricIdentifier, getScopeComponents, histogram, histogram, isClosed
public JobManagerJobMetricGroup(MetricRegistry registry, JobManagerMetricGroup parent, org.apache.flink.api.common.JobID jobId, @Nullable String jobName)
public JobManagerJobMetricGroup(MetricRegistry registry, JobManagerMetricGroup parent, JobManagerJobScopeFormat scopeFormat, org.apache.flink.api.common.JobID jobId, @Nullable String jobName)
public final JobManagerMetricGroup parent()
protected Iterable<? extends ComponentMetricGroup> subComponents()
ComponentMetricGroup
subComponents
in class ComponentMetricGroup
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.