Uses of Class
org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
-
-
Uses of TaskManagerMetricGroup in org.apache.flink.runtime.metrics.groups
Subclasses of TaskManagerMetricGroup in org.apache.flink.runtime.metrics.groups Modifier and Type Class Description static classUnregisteredMetricGroups.UnregisteredTaskManagerMetricGroupA safe drop-in replacement forTaskManagerMetricGroups.Methods in org.apache.flink.runtime.metrics.groups that return TaskManagerMetricGroup Modifier and Type Method Description static TaskManagerMetricGroupTaskManagerMetricGroup. createTaskManagerMetricGroup(MetricRegistry metricRegistry, String hostName, ResourceID resourceID)static TaskManagerMetricGroupUnregisteredMetricGroups. createUnregisteredTaskManagerMetricGroup()TaskManagerMetricGroupTaskManagerJobMetricGroup. parent()Constructors in org.apache.flink.runtime.metrics.groups with parameters of type TaskManagerMetricGroup Constructor Description TaskManagerJobMetricGroup(MetricRegistry registry, TaskManagerMetricGroup parent, org.apache.flink.api.common.JobID jobId, String jobName) -
Uses of TaskManagerMetricGroup in org.apache.flink.runtime.metrics.scope
Methods in org.apache.flink.runtime.metrics.scope with parameters of type TaskManagerMetricGroup Modifier and Type Method Description String[]TaskManagerJobScopeFormat. formatScope(TaskManagerMetricGroup parent, org.apache.flink.api.common.JobID jid, String jobName) -
Uses of TaskManagerMetricGroup in org.apache.flink.runtime.metrics.util
Methods in org.apache.flink.runtime.metrics.util that return types with arguments of type TaskManagerMetricGroup Modifier and Type Method Description static org.apache.flink.api.java.tuple.Tuple2<TaskManagerMetricGroup,org.apache.flink.metrics.MetricGroup>MetricUtils. instantiateTaskManagerMetricGroup(MetricRegistry metricRegistry, String hostName, ResourceID resourceID, Optional<Duration> systemResourceProbeInterval) -
Uses of TaskManagerMetricGroup in org.apache.flink.runtime.taskexecutor
Constructors in org.apache.flink.runtime.taskexecutor with parameters of type TaskManagerMetricGroup Constructor Description TaskExecutor(org.apache.flink.runtime.rpc.RpcService rpcService, TaskManagerConfiguration taskManagerConfiguration, HighAvailabilityServices haServices, TaskManagerServices taskExecutorServices, ExternalResourceInfoProvider externalResourceInfoProvider, HeartbeatServices heartbeatServices, TaskManagerMetricGroup taskManagerMetricGroup, String metricQueryServiceAddress, TaskExecutorBlobService taskExecutorBlobService, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, TaskExecutorPartitionTracker partitionTracker, DelegationTokenReceiverRepository delegationTokenReceiverRepository)
-