@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) | 
| org.apache.hadoop.yarn.api.records.Resource | getAMResourceUsage()Get resource usage of the AM. | 
| long | getAMResourceUsageMB()Get the AM memory usage in MB. | 
| int | getAMResourceUsageVCores()Get the AM VCore usage. | 
| org.apache.hadoop.yarn.api.records.Resource | getFairShare()Get instantaneous fair share of the queue. | 
| org.apache.hadoop.yarn.api.records.Resource | getMaxAMShare()Get maximum resource AM can use. | 
| 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() | 
| org.apache.hadoop.yarn.api.records.Resource | getMaxShare()Get maximum allowed resource share for queue. | 
| long | getMaxShareMB() | 
| long | getMaxShareVirtualCores() | 
| org.apache.hadoop.yarn.api.records.Resource | getMinShare()Get minimum required resource share for queue. | 
| long | getMinShareMB() | 
| long | getMinShareVirtualCores() | 
| String | getSchedulingPolicy()Get the scheduling policy. | 
| org.apache.hadoop.yarn.api.records.Resource | getSteadyFairShare()Get steady fair share for queue. | 
| 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)Set instantaneous fair share of the queue. | 
| 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)Set maximum allowed resource share for queue. | 
| void | setMinShare(org.apache.hadoop.yarn.api.records.Resource resource)Set minimum required resource share for queue. | 
| void | setSchedulingPolicy(String policy) | 
| void | setSteadyFairShare(org.apache.hadoop.yarn.api.records.Resource resource)Set steady fair share for queue. | 
activateApp, addAppAttemptFirstContainerAllocationDelay, allocateResources, allocateResources, clearQueueMetrics, createQueueMetricsForCustomResources, deactivateApp, decrActiveUsers, decrPendingResources, decrReserveResource, fillInValuesFromAvailableResources, 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, internalAllocateResources, internalDecrPendingResources, internalIncrPendingResources, internalReleaseResources, internalReserveResources, internalUnReserveResources, moveAppFrom, moveAppTo, preemptContainer, registerCustomResources, releaseResources, reserveResource, runAppAttempt, setAvailableResources, setAvailableResourcesToQueue, setAvailableResourcesToQueue, setAvailableResourcesToUser, setParent, setQueueMetricsForCustomResources, sourceName, submitApp, submitAppAttempt, tag, unreserveResource, updatePreemptedForCustomResources, updatePreemptedMemoryMBSeconds, updatePreemptedResources, updatePreemptedSecondsForCustomResources, updatePreemptedVcoreSecondspublic org.apache.hadoop.yarn.api.records.Resource getFairShare()
Resource also contains custom resource typespublic void setFairShare(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the passed Resource object may also contain custom
                 resource typespublic long getSteadyFairShareMB()
public long getSteadyFairShareVCores()
public org.apache.hadoop.yarn.api.records.Resource getSteadyFairShare()
Resource also contains custom resource typespublic void setSteadyFairShare(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the passed Resource object may also contain custom
                 resource typespublic long getMinShareMB()
public long getMinShareVirtualCores()
public org.apache.hadoop.yarn.api.records.Resource getMinShare()
Resource also contains custom resource typespublic void setMinShare(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the passed Resource object may also contain custom
                 resource typespublic long getMaxShareMB()
public long getMaxShareVirtualCores()
public org.apache.hadoop.yarn.api.records.Resource getMaxShare()
Resource also contains custom resource typespublic void setMaxShare(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the passed Resource object may also contain custom
                 resource typespublic int getMaxApps()
public void setMaxApps(int max)
public long getMaxAMShareMB()
public int getMaxAMShareVCores()
public org.apache.hadoop.yarn.api.records.Resource getMaxAMShare()
Resource also contains custom resource typespublic void setMaxAMShare(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the passed Resource object may also contain custom
                 resource typespublic long getAMResourceUsageMB()
public int getAMResourceUsageVCores()
public org.apache.hadoop.yarn.api.records.Resource getAMResourceUsage()
Resource also contains custom resource typespublic void setAMResourceUsage(org.apache.hadoop.yarn.api.records.Resource resource)
resource - the passed Resource object may also contain custom
                 resource types@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 © 2008–2023 Apache Software Foundation. All rights reserved.