@Metrics(context="yarn") public class FSQueueMetrics extends QueueMetrics
conf, DEFAULT_PARTITION, DEFAULT_PARTITION_JMX_STR, METRIC_NAME_DELIMITER, metricsSystem, P_RECORD_INFO, PARTITION_INFO, QUEUE_INFO, queueName, registry, USER_INFO, users| Modifier and Type | Method and Description | 
|---|---|
| static FSQueueMetrics | forQueue(org.apache.hadoop.metrics2.MetricsSystem ms,
        String queueName,
        Queue parent,
        boolean enableUserMetrics,
        org.apache.hadoop.conf.Configuration conf)Get the FS queue metric for the given queue. | 
| static FSQueueMetrics | forQueue(String queueName,
        Queue parent,
        boolean enableUserMetrics,
        org.apache.hadoop.conf.Configuration conf) | 
| long | getAMResourceUsageMB()Get the AM memory usage in MB. | 
| int | getAMResourceUsageVCores()Get the AM VCore usage. | 
| long | getFairShareMB() | 
| long | getFairShareVirtualCores() | 
| long | getMaxAMShareMB()Get the maximum memory size AM can use in MB. | 
| int | getMaxAMShareVCores()Get the maximum number of VCores AM can use. | 
| int | getMaxApps() | 
| long | getMaxShareMB() | 
| long | getMaxShareVirtualCores() | 
| long | getMinShareMB() | 
| long | getMinShareVirtualCores() | 
| String | getSchedulingPolicy()Get the scheduling policy. | 
| long | getSteadyFairShareMB() | 
| long | getSteadyFairShareVCores() | 
| void | setAMResourceUsage(org.apache.hadoop.yarn.api.records.Resource resource)Set the AM resource usage. | 
| void | setFairShare(org.apache.hadoop.yarn.api.records.Resource resource) | 
| void | setMaxAMShare(org.apache.hadoop.yarn.api.records.Resource resource)Set the maximum resource AM can use. | 
| void | setMaxApps(int max) | 
| void | setMaxShare(org.apache.hadoop.yarn.api.records.Resource resource) | 
| void | setMinShare(org.apache.hadoop.yarn.api.records.Resource resource) | 
| void | setSchedulingPolicy(String policy) | 
| void | setSteadyFairShare(org.apache.hadoop.yarn.api.records.Resource resource) | 
activateApp, addAppAttemptFirstContainerAllocationDelay, allocateResources, allocateResources, clearQueueMetrics, createQueueMetricsForCustomResources, deactivateApp, decrActiveUsers, decrPendingResources, decrReserveResource, finishApp, finishAppAttempt, getActiveApps, getActiveUsers, getAggegatedReleasedContainers, getAggregateAllocatedContainers, getAggregatedPreemptedSecondsResources, getAggregateMemoryMBPreempted, getAggregateMemoryMBSecondsPreempted, getAggregateNodeLocalContainersAllocated, getAggregateOffSwitchContainersAllocated, getAggregatePreemptedContainers, getAggregateRackLocalContainersAllocated, getAggregateVcoreSecondsPreempted, getAggregateVcoresPreempted, getAllocatedContainers, getAllocatedMB, getAllocatedResources, getAllocatedVirtualCores, getAppsCompleted, getAppsFailed, getAppsKilled, getAppsPending, getAppsRunning, getAppsSubmitted, getAvailableMB, getAvailableResources, getAvailableVirtualCores, getMetrics, getMetricsSystem, getParentQueue, getPartitionQueueMetrics, getPendingContainers, getPendingMB, getPendingResources, getPendingVirtualCores, getQueueMetrics, getQueueMetricsForCustomResources, getReservedContainers, getReservedMB, getReservedResources, getReservedVirtualCores, getUserMetrics, incrActiveUsers, incrNodeTypeAggregations, incrPendingResources, incrReserveResources, initAndGetCustomResources, internalAllocateResources, internalDecrPendingResources, internalIncrPendingResources, internalReleaseResources, internalReserveResources, internalUnReserveResources, moveAppFrom, moveAppTo, preemptContainer, registerCustomResources, registerCustomResources, releaseResources, reserveResource, runAppAttempt, setAvailableResources, setAvailableResourcesToQueue, setAvailableResourcesToQueue, setAvailableResourcesToUser, setParent, setQueueMetricsForCustomResources, sourceName, submitApp, submitAppAttempt, tag, unreserveResource, updatePreemptedMemoryMBSeconds, updatePreemptedResources, updatePreemptedSecondsForCustomResources, updatePreemptedVcoreSecondspublic void setFairShare(org.apache.hadoop.yarn.api.records.Resource resource)
public long getFairShareMB()
public long getFairShareVirtualCores()
public void setSteadyFairShare(org.apache.hadoop.yarn.api.records.Resource resource)
public long getSteadyFairShareMB()
public long getSteadyFairShareVCores()
public void setMinShare(org.apache.hadoop.yarn.api.records.Resource resource)
public long getMinShareMB()
public long getMinShareVirtualCores()
public void setMaxShare(org.apache.hadoop.yarn.api.records.Resource resource)
public long getMaxShareMB()
public long getMaxShareVirtualCores()
public int getMaxApps()
public void setMaxApps(int max)
public long getMaxAMShareMB()
public int getMaxAMShareVCores()
public void setMaxAMShare(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the maximum resource AM can usepublic long getAMResourceUsageMB()
public int getAMResourceUsageVCores()
public void setAMResourceUsage(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the AM resource usage@Metric(value="Scheduling policy") public String getSchedulingPolicy()
public void setSchedulingPolicy(String policy)
public static FSQueueMetrics forQueue(String queueName, Queue parent, boolean enableUserMetrics, org.apache.hadoop.conf.Configuration conf)
public static FSQueueMetrics forQueue(org.apache.hadoop.metrics2.MetricsSystem ms, String queueName, Queue parent, boolean enableUserMetrics, org.apache.hadoop.conf.Configuration conf)
ms - the metric systemqueueName - queue nameparent - parent queueenableUserMetrics - if user metrics is neededconf - configurationCopyright © 2022 Apache Software Foundation. All rights reserved.