public class RMAppAttemptMetrics extends Object
Constructor and Description |
---|
RMAppAttemptMetrics(org.apache.hadoop.yarn.api.records.ApplicationAttemptId attemptId,
RMContext rmContext) |
Modifier and Type | Method and Description |
---|---|
AggregateAppResourceUsage |
getAggregateAppResourceUsage() |
org.apache.hadoop.yarn.api.records.Resource |
getApplicationAttemptHeadroom() |
boolean |
getIsPreempted() |
int[][] |
getLocalityStatistics() |
int |
getNumNonAMContainersPreempted() |
long |
getPreemptedMemory() |
Map<String,Long> |
getPreemptedResourceSecondsMap() |
long |
getPreemptedVcore() |
org.apache.hadoop.yarn.api.records.Resource |
getResourcePreempted() |
int |
getTotalAllocatedContainers() |
void |
incNumAllocatedContainers(NodeType containerType,
NodeType requestType) |
void |
setApplicationAttemptHeadRoom(org.apache.hadoop.yarn.api.records.Resource headRoom) |
void |
setIsPreempted() |
void |
setTotalAllocatedContainers(int totalAllocatedContainers) |
void |
updateAggregateAppResourceUsage(Map<String,Long> resourceSecondsMap) |
void |
updateAggregateAppResourceUsage(org.apache.hadoop.yarn.api.records.Resource allocated,
long deltaUsedMillis) |
void |
updateAggregatePreemptedAppResourceUsage(Map<String,Long> preemptedResourceSecondsMap) |
void |
updateAggregatePreemptedAppResourceUsage(org.apache.hadoop.yarn.api.records.Resource allocated,
long deltaUsedMillis) |
void |
updatePreemptionInfo(org.apache.hadoop.yarn.api.records.Resource resource,
RMContainer container) |
public RMAppAttemptMetrics(org.apache.hadoop.yarn.api.records.ApplicationAttemptId attemptId, RMContext rmContext)
public void updatePreemptionInfo(org.apache.hadoop.yarn.api.records.Resource resource, RMContainer container)
public org.apache.hadoop.yarn.api.records.Resource getResourcePreempted()
public long getPreemptedMemory()
public long getPreemptedVcore()
public int getNumNonAMContainersPreempted()
public void setIsPreempted()
public boolean getIsPreempted()
public AggregateAppResourceUsage getAggregateAppResourceUsage()
public void updateAggregateAppResourceUsage(org.apache.hadoop.yarn.api.records.Resource allocated, long deltaUsedMillis)
public void updateAggregatePreemptedAppResourceUsage(org.apache.hadoop.yarn.api.records.Resource allocated, long deltaUsedMillis)
public void updateAggregateAppResourceUsage(Map<String,Long> resourceSecondsMap)
public void updateAggregatePreemptedAppResourceUsage(Map<String,Long> preemptedResourceSecondsMap)
public void incNumAllocatedContainers(NodeType containerType, NodeType requestType)
public int[][] getLocalityStatistics()
public int getTotalAllocatedContainers()
public void setTotalAllocatedContainers(int totalAllocatedContainers)
public org.apache.hadoop.yarn.api.records.Resource getApplicationAttemptHeadroom()
public void setApplicationAttemptHeadRoom(org.apache.hadoop.yarn.api.records.Resource headRoom)
Copyright © 2020 Apache Software Foundation. All rights reserved.