public class TaskManagerMetricGroup extends ComponentMetricGroup
MetricGroup
representing a TaskManager.
Contains extra logic for adding jobs with tasks, and removing jobs when they do not contain tasks any more
registry
Constructor and Description |
---|
TaskManagerMetricGroup(MetricRegistry registry,
String hostname,
String taskManagerId) |
TaskManagerMetricGroup(MetricRegistry registry,
TaskManagerScopeFormat scopeFormat,
String hostname,
String taskManagerId) |
Modifier and Type | Method and Description |
---|---|
TaskMetricGroup |
addTaskForJob(TaskDeploymentDescriptor tdd) |
String |
hostname() |
int |
numRegisteredJobMetricGroups() |
void |
removeJobMetricsGroup(org.apache.flink.api.common.JobID jobId,
TaskManagerJobMetricGroup group) |
protected Iterable<? extends ComponentMetricGroup> |
subComponents()
Gets all component metric groups that are contained in this component metric group.
|
String |
taskManagerId() |
close
addGroup, addGroup, addMetric, counter, counter, counter, counter, gauge, gauge, getMetricIdentifier, getMetricIdentifier, getScopeComponents, histogram, histogram, isClosed
public TaskManagerMetricGroup(MetricRegistry registry, String hostname, String taskManagerId)
public TaskManagerMetricGroup(MetricRegistry registry, TaskManagerScopeFormat scopeFormat, String hostname, String taskManagerId)
public String hostname()
public String taskManagerId()
public TaskMetricGroup addTaskForJob(TaskDeploymentDescriptor tdd)
public void removeJobMetricsGroup(org.apache.flink.api.common.JobID jobId, TaskManagerJobMetricGroup group)
public int numRegisteredJobMetricGroups()
protected Iterable<? extends ComponentMetricGroup> subComponents()
ComponentMetricGroup
subComponents
in class ComponentMetricGroup
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.