public class SchedulerHealth extends Object
SchedulerHealth
provides clients with information such as:
Modifier and Type | Class and Description |
---|---|
static class |
SchedulerHealth.DetailedInformation |
Modifier and Type | Method and Description |
---|---|
Long |
getAggregateAllocationCount()
Get the aggregate of all the allocations count.
|
Long |
getAggregateFulFilledReservationsCount()
Get the aggregate of all the fulfilled reservations count.
|
Long |
getAggregatePreemptionCount()
Get the aggregate of all the preemption count.
|
Long |
getAggregateReleaseCount()
Get the aggregate of all the release count.
|
Long |
getAggregateReservationCount()
Get the aggregate of all the reservations count.
|
Long |
getAllocationCount()
Get the count of allocation from the latest scheduler health report.
|
SchedulerHealth.DetailedInformation |
getLastAllocationDetails()
Get the details of last allocation.
|
SchedulerHealth.DetailedInformation |
getLastPreemptionDetails()
Get the details of last preemption.
|
SchedulerHealth.DetailedInformation |
getLastReleaseDetails()
Get the details of last release.
|
SchedulerHealth.DetailedInformation |
getLastReservationDetails()
Get the details of last reservation.
|
long |
getLastSchedulerRunTime()
Get the timestamp of the latest scheduler operation.
|
Long |
getPreemptionCount()
Get the count of preemption from the latest scheduler health report.
|
Long |
getReleaseCount()
Get the count of release from the latest scheduler health report.
|
Long |
getReservationCount()
Get the count of reservation from the latest scheduler health report.
|
org.apache.hadoop.yarn.api.records.Resource |
getResourcesAllocated()
Get the resources allocated in the last scheduler run.
|
org.apache.hadoop.yarn.api.records.Resource |
getResourcesReleased()
Get the resources released in the last scheduler run.
|
org.apache.hadoop.yarn.api.records.Resource |
getResourcesReserved()
Get the resources reserved in the last scheduler run.
|
void |
updateAllocation(long timestamp,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
String queue) |
void |
updatePreemption(long timestamp,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
String queue) |
void |
updateRelease(long timestamp,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
String queue) |
void |
updateReservation(long timestamp,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
String queue) |
void |
updateSchedulerAllocationCounts(long count) |
void |
updateSchedulerFulfilledReservationCounts(long count) |
void |
updateSchedulerPreemptionCounts(long count) |
void |
updateSchedulerReleaseCounts(long count) |
void |
updateSchedulerReleaseDetails(long timestamp,
org.apache.hadoop.yarn.api.records.Resource released) |
void |
updateSchedulerReservationCounts(long count) |
void |
updateSchedulerRunDetails(long timestamp,
org.apache.hadoop.yarn.api.records.Resource allocated,
org.apache.hadoop.yarn.api.records.Resource reserved) |
public void updateAllocation(long timestamp, org.apache.hadoop.yarn.api.records.NodeId nodeId, org.apache.hadoop.yarn.api.records.ContainerId containerId, String queue)
public void updateRelease(long timestamp, org.apache.hadoop.yarn.api.records.NodeId nodeId, org.apache.hadoop.yarn.api.records.ContainerId containerId, String queue)
public void updatePreemption(long timestamp, org.apache.hadoop.yarn.api.records.NodeId nodeId, org.apache.hadoop.yarn.api.records.ContainerId containerId, String queue)
public void updateReservation(long timestamp, org.apache.hadoop.yarn.api.records.NodeId nodeId, org.apache.hadoop.yarn.api.records.ContainerId containerId, String queue)
public void updateSchedulerRunDetails(long timestamp, org.apache.hadoop.yarn.api.records.Resource allocated, org.apache.hadoop.yarn.api.records.Resource reserved)
public void updateSchedulerReleaseDetails(long timestamp, org.apache.hadoop.yarn.api.records.Resource released)
public void updateSchedulerReleaseCounts(long count)
public void updateSchedulerAllocationCounts(long count)
public void updateSchedulerReservationCounts(long count)
public void updateSchedulerFulfilledReservationCounts(long count)
public void updateSchedulerPreemptionCounts(long count)
public long getLastSchedulerRunTime()
public org.apache.hadoop.yarn.api.records.Resource getResourcesAllocated()
public org.apache.hadoop.yarn.api.records.Resource getResourcesReserved()
public org.apache.hadoop.yarn.api.records.Resource getResourcesReleased()
public SchedulerHealth.DetailedInformation getLastAllocationDetails()
public SchedulerHealth.DetailedInformation getLastReleaseDetails()
public SchedulerHealth.DetailedInformation getLastReservationDetails()
public SchedulerHealth.DetailedInformation getLastPreemptionDetails()
public Long getAllocationCount()
public Long getReleaseCount()
public Long getReservationCount()
public Long getPreemptionCount()
public Long getAggregateAllocationCount()
public Long getAggregateReleaseCount()
public Long getAggregateReservationCount()
public Long getAggregatePreemptionCount()
public Long getAggregateFulFilledReservationsCount()
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.