Modifier and Type | Method and Description |
---|---|
void |
RMApplicationHistoryWriter.containerFinished(RMContainer container) |
void |
RMApplicationHistoryWriter.containerStarted(RMContainer container) |
Modifier and Type | Method and Description |
---|---|
void |
SystemMetricsPublisher.containerCreated(RMContainer container,
long createdTime) |
void |
SystemMetricsPublisher.containerFinished(RMContainer container,
long finishedTime) |
Modifier and Type | Method and Description |
---|---|
void |
RMAppAttemptMetrics.updatePreemptionInfo(org.apache.hadoop.yarn.api.records.Resource resource,
RMContainer container) |
Modifier and Type | Class and Description |
---|---|
class |
RMContainerImpl |
Modifier and Type | Field and Description |
---|---|
protected Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
SchedulerApplicationAttempt.liveContainers |
protected List<RMContainer> |
SchedulerApplicationAttempt.newlyAllocatedContainers |
protected Map<org.apache.hadoop.yarn.api.records.Priority,Map<org.apache.hadoop.yarn.api.records.NodeId,RMContainer>> |
SchedulerApplicationAttempt.reservedContainers |
Modifier and Type | Method and Description |
---|---|
RMContainer |
ContainerPreemptEvent.getContainer() |
RMContainer |
SchedulerNode.getReservedContainer() |
RMContainer |
SchedulerApplicationAttempt.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId id) |
RMContainer |
YarnScheduler.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId)
Get the container for the given containerId.
|
RMContainer |
AbstractYarnScheduler.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
RMContainer |
SchedulerApplicationAttempt.reserve(SchedulerNode node,
org.apache.hadoop.yarn.api.records.Priority priority,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Container container) |
Modifier and Type | Method and Description |
---|---|
Collection<RMContainer> |
SchedulerApplicationAttempt.getLiveContainers()
Get the live containers of the application.
|
Collection<RMContainer> |
SchedulerAppReport.getLiveContainers()
Get the list of live containers
|
Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
SchedulerApplicationAttempt.getLiveContainersMap() |
List<RMContainer> |
SchedulerApplicationAttempt.getReservedContainers()
Get the list of reserved containers
|
Collection<RMContainer> |
SchedulerAppReport.getReservedContainers()
Get the list of reserved containers
|
List<RMContainer> |
SchedulerNode.getRunningContainers() |
Modifier and Type | Method and Description |
---|---|
void |
SchedulerNode.allocateContainer(RMContainer rmContainer)
The Scheduler has allocated containers on this node to the given
application.
|
protected abstract void |
AbstractYarnScheduler.completedContainer(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
void |
PreemptableResourceScheduler.dropContainerReservation(RMContainer container)
If the scheduler support container reservations, this method is used to
ask the scheduler to drop the reservation for the given container.
|
void |
PreemptableResourceScheduler.killContainer(RMContainer container)
Ask the scheduler to forcibly interrupt the container given as input
|
void |
PreemptableResourceScheduler.preemptContainer(org.apache.hadoop.yarn.api.records.ApplicationAttemptId aid,
RMContainer container)
Ask the scheduler to obtain back the container from a specific application
by issuing a preemption request
|
void |
Queue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt schedulerAttempt,
RMContainer rmContainer)
Recover the state of the queue for a given container.
|
void |
SchedulerApplicationAttempt.recoverContainer(RMContainer rmContainer) |
void |
AppSchedulingInfo.recoverContainer(RMContainer rmContainer) |
void |
SchedulerNode.recoverContainer(RMContainer rmContainer) |
protected void |
AbstractYarnScheduler.recoverResourceRequestForContainer(RMContainer rmContainer)
Recover resource request back from RMContainer when a container is
preempted before AM pulled the same.
|
RMContainer |
SchedulerApplicationAttempt.reserve(SchedulerNode node,
org.apache.hadoop.yarn.api.records.Priority priority,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Container container) |
abstract void |
SchedulerNode.reserveResource(SchedulerApplicationAttempt attempt,
org.apache.hadoop.yarn.api.records.Priority priority,
RMContainer container)
Reserve container for the attempt on this node.
|
protected void |
SchedulerNode.setReservedContainer(RMContainer reservedContainer) |
Constructor and Description |
---|
ContainerPreemptEvent(org.apache.hadoop.yarn.api.records.ApplicationAttemptId aid,
RMContainer container,
ContainerPreemptEventType type) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
CSAssignment.getExcessReservation() |
Modifier and Type | Method and Description |
---|---|
void |
CSQueue.attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer container)
Attach a container to this queue
|
void |
LeafQueue.attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
ParentQueue.attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
CSQueue.completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
FiCaSchedulerNode node,
RMContainer container,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
CSQueue childQueue,
boolean sortQueues)
A container assigned to the queue has completed.
|
void |
LeafQueue.completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
FiCaSchedulerNode node,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
CSQueue childQueue,
boolean sortQueues) |
void |
ParentQueue.completedContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
FiCaSchedulerNode node,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
CSQueue completedChildQueue,
boolean sortQueues) |
protected void |
CapacityScheduler.completedContainer(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
void |
CSQueue.detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer container)
Detach a container from this queue
|
void |
LeafQueue.detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
ParentQueue.detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
CapacityScheduler.dropContainerReservation(RMContainer container) |
void |
CapacityScheduler.killContainer(RMContainer cont) |
void |
CapacityScheduler.preemptContainer(org.apache.hadoop.yarn.api.records.ApplicationAttemptId aid,
RMContainer cont) |
void |
LeafQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt attempt,
RMContainer rmContainer) |
void |
ParentQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt attempt,
RMContainer rmContainer) |
Constructor and Description |
---|
CSAssignment(FiCaSchedulerApp application,
RMContainer excessReservation) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FiCaSchedulerApp.allocate(NodeType type,
FiCaSchedulerNode node,
org.apache.hadoop.yarn.api.records.Priority priority,
org.apache.hadoop.yarn.api.records.ResourceRequest request,
org.apache.hadoop.yarn.api.records.Container container) |
Modifier and Type | Method and Description |
---|---|
boolean |
FiCaSchedulerApp.containerCompleted(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
void |
FiCaSchedulerNode.reserveResource(SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.api.records.Priority priority,
RMContainer container) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
ContainerRescheduledEvent.getContainer() |
Constructor and Description |
---|
ContainerRescheduledEvent(RMContainer container) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FSAppAttempt.allocate(NodeType type,
FSSchedulerNode node,
org.apache.hadoop.yarn.api.records.Priority priority,
org.apache.hadoop.yarn.api.records.ResourceRequest request,
org.apache.hadoop.yarn.api.records.Container container) |
RMContainer |
FSAppAttempt.preemptContainer()
Preempt a running container according to the priority
|
RMContainer |
Schedulable.preemptContainer()
Preempt a container from this Schedulable if possible.
|
RMContainer |
FSLeafQueue.preemptContainer() |
RMContainer |
FSParentQueue.preemptContainer() |
Modifier and Type | Method and Description |
---|---|
Set<RMContainer> |
FSAppAttempt.getNonEligibleForPreemptionSet() |
Set<RMContainer> |
FSAppAttempt.getPreemptionContainers() |
Modifier and Type | Method and Description |
---|---|
void |
FSAppAttempt.addNonEligibleForPreemption(RMContainer container) |
void |
FSAppAttempt.addPreemption(RMContainer container,
long time) |
protected void |
FairScheduler.completedContainer(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event)
Clean up a completed container.
|
void |
FSAppAttempt.containerCompleted(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
Long |
FSAppAttempt.getContainerPreemptionTime(RMContainer container) |
void |
FSLeafQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt schedulerAttempt,
RMContainer rmContainer) |
void |
FSParentQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt schedulerAttempt,
RMContainer rmContainer) |
void |
FSSchedulerNode.reserveResource(SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.api.records.Priority priority,
RMContainer container) |
protected void |
FairScheduler.warnOrKillContainer(RMContainer container) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FifoScheduler.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
Modifier and Type | Method and Description |
---|---|
protected void |
FifoScheduler.completedContainer(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
Copyright © 2019 Apache Software Foundation. All Rights Reserved.