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 |
TimelineServiceV2Publisher.containerCreated(RMContainer container,
long createdTime) |
void |
TimelineServiceV1Publisher.containerCreated(RMContainer container,
long createdTime) |
void |
CombinedSystemMetricsPublisher.containerCreated(RMContainer container,
long createdTime) |
void |
NoOpSystemMetricPublisher.containerCreated(RMContainer container,
long createdTime) |
void |
SystemMetricsPublisher.containerFinished(RMContainer container,
long finishedTime) |
void |
TimelineServiceV2Publisher.containerFinished(RMContainer container,
long finishedTime) |
void |
TimelineServiceV1Publisher.containerFinished(RMContainer container,
long finishedTime) |
void |
CombinedSystemMetricsPublisher.containerFinished(RMContainer container,
long finishedTime) |
void |
NoOpSystemMetricPublisher.containerFinished(RMContainer container,
long finishedTime) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
TempSchedulerNode.getReservedContainer() |
Modifier and Type | Method and Description |
---|---|
List<RMContainer> |
TempSchedulerNode.getRunningContainers() |
Map<RMContainer,Long> |
ProportionalCapacityPreemptionPolicy.getToPreemptContainers() |
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
FifoCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed) |
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
QueuePriorityContainerCandidateSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed) |
abstract Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
PreemptionCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed)
Get preemption candidates from computed resource sharing and already
selected candidates.
|
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
IntraQueueCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed) |
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
ReservedContainerCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed) |
Modifier and Type | Method and Description |
---|---|
protected static void |
CapacitySchedulerPreemptionUtils.addToPreemptMap(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> preemptMap,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> curCandidates,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
RMContainer containerToPreempt) |
static boolean |
CapacitySchedulerPreemptionUtils.isContainerAlreadySelected(RMContainer container,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates) |
void |
TempSchedulerNode.setReservedContainer(RMContainer reservedContainer) |
boolean |
FifoIntraQueuePreemptionPlugin.skipContainerBasedOnIntraQueuePolicy(FiCaSchedulerApp app,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource usedResource,
RMContainer c) |
static boolean |
CapacitySchedulerPreemptionUtils.tryPreemptContainerAndDeductResToObtain(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
CapacitySchedulerPreemptionContext context,
Map<String,org.apache.hadoop.yarn.api.records.Resource> resourceToObtainByPartitions,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> preemptMap,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> curCandidates,
org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed,
boolean conservativeDRF)
Invoke this method to preempt container based on resToObtain.
|
Modifier and Type | Method and Description |
---|---|
protected static void |
CapacitySchedulerPreemptionUtils.addToPreemptMap(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> preemptMap,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> curCandidates,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
RMContainer containerToPreempt) |
protected static void |
CapacitySchedulerPreemptionUtils.addToPreemptMap(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> preemptMap,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> curCandidates,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
RMContainer containerToPreempt) |
void |
FifoIntraQueuePreemptionPlugin.computeAppsIdealAllocation(org.apache.hadoop.yarn.api.records.Resource clusterResource,
TempQueuePerPartition tq,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed,
org.apache.hadoop.yarn.api.records.Resource queueReassignableResource,
float maxAllowablePreemptLimit) |
static void |
CapacitySchedulerPreemptionUtils.deductPreemptableResourcesBasedSelectedCandidates(CapacitySchedulerPreemptionContext context,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates) |
static boolean |
CapacitySchedulerPreemptionUtils.isContainerAlreadySelected(RMContainer container,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates) |
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
FifoCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed) |
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
QueuePriorityContainerCandidateSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed) |
abstract Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
PreemptionCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed)
Get preemption candidates from computed resource sharing and already
selected candidates.
|
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
IntraQueueCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed) |
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> |
ReservedContainerCandidatesSelector.selectCandidates(Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> selectedCandidates,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
org.apache.hadoop.yarn.api.records.Resource totalPreemptedResourceAllowed) |
void |
TempSchedulerNode.setRunningContainers(List<RMContainer> runningContainers) |
static boolean |
CapacitySchedulerPreemptionUtils.tryPreemptContainerAndDeductResToObtain(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
CapacitySchedulerPreemptionContext context,
Map<String,org.apache.hadoop.yarn.api.records.Resource> resourceToObtainByPartitions,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> preemptMap,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> curCandidates,
org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed,
boolean conservativeDRF)
Invoke this method to preempt container based on resToObtain.
|
static boolean |
CapacitySchedulerPreemptionUtils.tryPreemptContainerAndDeductResToObtain(org.apache.hadoop.yarn.util.resource.ResourceCalculator rc,
CapacitySchedulerPreemptionContext context,
Map<String,org.apache.hadoop.yarn.api.records.Resource> resourceToObtainByPartitions,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Resource clusterResource,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> preemptMap,
Map<org.apache.hadoop.yarn.api.records.ApplicationAttemptId,Set<RMContainer>> curCandidates,
org.apache.hadoop.yarn.api.records.Resource totalPreemptionAllowed,
boolean conservativeDRF)
Invoke this method to preempt container based on resToObtain.
|
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 | Method and Description |
---|---|
int |
RMContainerImpl.compareTo(RMContainer o) |
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.ContainerId,RMContainer> |
SchedulerApplicationAttempt.newlyDecreasedContainers |
protected Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
SchedulerApplicationAttempt.newlyDemotedContainers |
protected Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
SchedulerApplicationAttempt.newlyIncreasedContainers |
protected Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
SchedulerApplicationAttempt.newlyPromotedContainers |
protected Map<org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey,Map<org.apache.hadoop.yarn.api.records.NodeId,RMContainer>> |
SchedulerApplicationAttempt.reservedContainers |
protected List<RMContainer> |
SchedulerApplicationAttempt.tempContainerToKill |
Modifier and Type | Method and Description |
---|---|
static RMContainer |
SchedulerUtils.createOpportunisticRmContainer(RMContext rmContext,
org.apache.hadoop.yarn.api.records.Container container,
boolean isRemotelyAllocated) |
protected RMContainer |
SchedulerNode.getContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId)
Get the container for the specified container ID.
|
RMContainer |
SchedulerNode.getReservedContainer()
Get the reserved container in the node.
|
RMContainer |
SchedContainerChangeRequest.getRMContainer() |
RMContainer |
SchedulerApplicationAttempt.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId id) |
RMContainer |
AbstractYarnScheduler.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
RMContainer |
YarnScheduler.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId)
Get the container for the given containerId.
|
RMContainer |
SchedulerApplicationAttempt.reserve(SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Container container) |
RMContainer |
ContainerUpdateContext.swapContainer(RMContainer tempRMContainer,
RMContainer existingRMContainer,
org.apache.hadoop.yarn.api.records.ContainerUpdateType updateType)
Swaps the existing RMContainer's and the temp RMContainers internal
container references after adjusting the resources in each.
|
Modifier and Type | Method and Description |
---|---|
List<RMContainer> |
SchedulerNode.getContainersToKill()
Get the containers running on the node ordered by which to kill first.
|
List<RMContainer> |
SchedulerNode.getCopiedListOfRunningContainers()
Get the containers running on the node.
|
protected List<RMContainer> |
SchedulerNode.getLaunchedContainers()
Get the launched containers in the node.
|
Collection<RMContainer> |
SchedulerAppReport.getLiveContainers()
Get the list of live containers
|
Collection<RMContainer> |
SchedulerApplicationAttempt.getLiveContainers()
Get the live containers of the application.
|
Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
SchedulerApplicationAttempt.getLiveContainersMap() |
Collection<RMContainer> |
SchedulerAppReport.getReservedContainers()
Get the list of reserved containers
|
List<RMContainer> |
SchedulerApplicationAttempt.getReservedContainers()
Get the list of reserved containers
|
List<RMContainer> |
SchedulerNode.getRunningContainersWithAMsAtTheEnd()
Get the containers running on the node with AM containers at the end.
|
Modifier and Type | Method and Description |
---|---|
void |
SchedulerApplicationAttempt.addRMContainer(org.apache.hadoop.yarn.api.records.ContainerId id,
RMContainer rmContainer) |
protected void |
SchedulerApplicationAttempt.addToNewlyAllocatedContainers(SchedulerNode node,
RMContainer rmContainer) |
void |
SchedulerApplicationAttempt.addToNewlyDecreasedContainers(org.apache.hadoop.yarn.api.records.ContainerId containerId,
RMContainer rmContainer) |
void |
SchedulerApplicationAttempt.addToNewlyDemotedContainers(org.apache.hadoop.yarn.api.records.ContainerId containerId,
RMContainer rmContainer) |
ContainerRequest |
AppSchedulingInfo.allocate(NodeType type,
SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer containerAllocated) |
void |
SchedulerNode.allocateContainer(RMContainer rmContainer)
The Scheduler has allocated containers on this node to the given
application.
|
protected void |
SchedulerNode.allocateContainer(RMContainer rmContainer,
boolean launchedOnNode)
The Scheduler has allocated containers on this node to the given
application.
|
void |
AbstractYarnScheduler.asyncContainerRelease(RMContainer container)
To be used to release a container via a Scheduler Event rather than
in the same thread.
|
boolean |
ContainerUpdateContext.checkAndAddToOutstandingIncreases(RMContainer rmContainer,
SchedulerNode schedulerNode,
org.apache.hadoop.yarn.api.records.UpdateContainerRequest updateRequest)
Add the container to outstanding increases.
|
void |
AbstractYarnScheduler.completedContainer(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
protected abstract void |
AbstractYarnScheduler.completedContainerInternal(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
abstract void |
AbstractYarnScheduler.killContainer(RMContainer container)
Kill a RMContainer.
|
void |
PreemptableResourceScheduler.killReservedContainer(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.markContainerForKillable(RMContainer container)
Ask the scheduler to forcibly interrupt the container given as input
|
void |
PreemptableResourceScheduler.markContainerForPreemption(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
|
org.apache.hadoop.yarn.api.records.ContainerId |
ContainerUpdateContext.matchContainerToOutstandingIncreaseReq(SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer rmContainer)
Check if a new container is to be matched up against an outstanding
Container increase 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 |
SchedulerNode.recoverContainer(RMContainer rmContainer)
Recover a container.
|
void |
AppSchedulingInfo.recoverContainer(RMContainer rmContainer,
String partition) |
void |
SchedulerApplicationAttempt.recoverContainer(SchedulerNode node,
RMContainer rmContainer) |
RMContainer |
SchedulerApplicationAttempt.reserve(SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Container container) |
boolean |
SchedulerApplicationAttempt.reserveIncreasedContainer(SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Resource reservedResource) |
abstract void |
SchedulerNode.reserveResource(SchedulerApplicationAttempt attempt,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer container)
Reserve container for the attempt on this node.
|
void |
SchedulerNode.setReservedContainer(RMContainer reservedContainer)
Set the reserved container in the node.
|
RMContainer |
ContainerUpdateContext.swapContainer(RMContainer tempRMContainer,
RMContainer existingRMContainer,
org.apache.hadoop.yarn.api.records.ContainerUpdateType updateType)
Swaps the existing RMContainer's and the temp RMContainers internal
container references after adjusting the resources in each.
|
static void |
AppSchedulingInfo.updateMetrics(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
NodeType type,
SchedulerNode node,
RMContainer containerAllocated,
String user,
Queue queue) |
Constructor and Description |
---|
SchedContainerChangeRequest(RMContext rmContext,
SchedulerNode schedulerNode,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Resource targetCapacity) |
Modifier and Type | Method and Description |
---|---|
static void |
ActivitiesLogger.APP.recordAppActivityWithAllocation(ActivitiesManager activitiesManager,
SchedulerNode node,
SchedulerApplicationAttempt application,
RMContainer updatedContainer,
ActivityState activityState) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
CSAssignment.getExcessReservation() |
RMContainer |
CSAssignment.getFulfilledReservedContainer() |
Modifier and Type | Method and Description |
---|---|
List<RMContainer> |
CSAssignment.getContainersToKill() |
Map<String,TreeSet<RMContainer>> |
LeafQueue.getIgnoreExclusivityRMContainers() |
Iterator<RMContainer> |
AbstractCSQueue.getKillableContainers(String partition) |
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 |
ParentQueue.attachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
LeafQueue.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 |
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) |
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) |
protected void |
CapacityScheduler.completedContainerInternal(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 |
ParentQueue.detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
LeafQueue.detachContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
FiCaSchedulerApp application,
RMContainer rmContainer) |
void |
CapacityScheduler.killContainer(RMContainer container) |
void |
CapacityScheduler.killReservedContainer(RMContainer container) |
void |
CapacityScheduler.markContainerForKillable(RMContainer killableContainer) |
void |
CapacityScheduler.markContainerForPreemption(org.apache.hadoop.yarn.api.records.ApplicationAttemptId aid,
RMContainer cont) |
boolean |
CapacityScheduler.moveReservedContainer(RMContainer toBeMovedContainer,
FiCaSchedulerNode targetNode)
Try to move a reserved container to a targetNode.
|
void |
ParentQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt attempt,
RMContainer rmContainer) |
void |
LeafQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt attempt,
RMContainer rmContainer) |
void |
CSAssignment.setExcessReservation(RMContainer rmContainer) |
void |
CSAssignment.setFulfilledReservedContainer(RMContainer fulfilledReservedContainer) |
Modifier and Type | Method and Description |
---|---|
void |
CSAssignment.setContainersToKill(List<RMContainer> containersToKill) |
Constructor and Description |
---|
CSAssignment(FiCaSchedulerApp application,
RMContainer excessReservation) |
CSAssignment(org.apache.hadoop.yarn.api.records.Resource resource,
NodeType type,
RMContainer excessReservation,
FiCaSchedulerApp application,
CSAssignment.SkippedType skipped,
boolean fulfilledReservation) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
ContainerAllocation.getContainerToBeUnreserved() |
RMContainer |
ContainerAllocation.getUpdatedContainer() |
Modifier and Type | Method and Description |
---|---|
List<RMContainer> |
ContainerAllocation.getToKillContainers() |
Modifier and Type | Method and Description |
---|---|
abstract CSAssignment |
AbstractContainerAllocator.assignContainers(org.apache.hadoop.yarn.api.records.Resource clusterResource,
CandidateNodeSet<FiCaSchedulerNode> candidates,
SchedulingMode schedulingMode,
ResourceLimits resourceLimits,
RMContainer reservedContainer)
allocate needs to handle following stuffs:
Select request: Select a request to allocate.
|
CSAssignment |
RegularContainerAllocator.assignContainers(org.apache.hadoop.yarn.api.records.Resource clusterResource,
CandidateNodeSet<FiCaSchedulerNode> candidates,
SchedulingMode schedulingMode,
ResourceLimits resourceLimits,
RMContainer reservedContainer) |
CSAssignment |
ContainerAllocator.assignContainers(org.apache.hadoop.yarn.api.records.Resource clusterResource,
CandidateNodeSet<FiCaSchedulerNode> candidates,
SchedulingMode schedulingMode,
ResourceLimits resourceLimits,
RMContainer reservedContainer) |
protected CSAssignment |
AbstractContainerAllocator.getCSAssignmentFromAllocateResult(org.apache.hadoop.yarn.api.records.Resource clusterResource,
ContainerAllocation result,
RMContainer rmContainer,
FiCaSchedulerNode node) |
Modifier and Type | Method and Description |
---|---|
void |
ContainerAllocation.setToKillContainers(List<RMContainer> toKillContainers) |
Constructor and Description |
---|
ContainerAllocation(RMContainer containerToBeUnreserved,
org.apache.hadoop.yarn.api.records.Resource resourceToBeAllocated,
AllocationState state) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
KillableContainer.getRMContainer() |
Modifier and Type | Method and Description |
---|---|
Map<String,Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer>> |
PreemptableQueue.getKillableContainers() |
Iterator<RMContainer> |
PreemptionManager.getKillableContainers(String queueName,
String partition) |
Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
PreemptionManager.getKillableContainersMap(String queueName,
String partition) |
Constructor and Description |
---|
KillableContainer(RMContainer container,
String partition,
String leafQueueName) |
Constructor and Description |
---|
PreemptableQueue(Map<String,org.apache.hadoop.yarn.api.records.Resource> totalKillableResources,
Map<String,Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer>> killableContainers) |
Modifier and Type | Field and Description |
---|---|
RMContainer |
AssignmentInformation.AssignmentDetails.rmContainer |
Modifier and Type | Method and Description |
---|---|
RMContainer |
AssignmentInformation.getFirstAllocatedOrReservedRMContainer() |
RMContainer |
SchedulerContainer.getRmContainer() |
Modifier and Type | Method and Description |
---|---|
void |
AssignmentInformation.addAllocationDetails(RMContainer rmContainer,
String queue) |
void |
AssignmentInformation.addReservationDetails(RMContainer rmContainer,
String queue) |
Constructor and Description |
---|
AssignmentDetails(RMContainer rmContainer,
String queue) |
SchedulerContainer(A app,
N node,
RMContainer rmContainer,
String nodePartition,
boolean allocated) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FiCaSchedulerApp.allocate(FiCaSchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
org.apache.hadoop.yarn.api.records.Container container) |
RMContainer |
FiCaSchedulerApp.findNodeToUnreserve(FiCaSchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
org.apache.hadoop.yarn.api.records.Resource minimumUnreservedResource) |
Modifier and Type | Method and Description |
---|---|
Map<org.apache.hadoop.yarn.api.records.ContainerId,RMContainer> |
FiCaSchedulerNode.getKillableContainers() |
Modifier and Type | Method and Description |
---|---|
protected void |
FiCaSchedulerNode.allocateContainer(RMContainer rmContainer,
boolean launchedOnNode) |
CSAssignment |
FiCaSchedulerApp.assignContainers(org.apache.hadoop.yarn.api.records.Resource clusterResource,
CandidateNodeSet<FiCaSchedulerNode> ps,
ResourceLimits currentResourceLimits,
SchedulingMode schedulingMode,
RMContainer reservedContainer) |
boolean |
FiCaSchedulerApp.containerCompleted(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event,
String partition) |
boolean |
FiCaSchedulerApp.moveReservation(RMContainer reservedContainer,
FiCaSchedulerNode sourceNode,
FiCaSchedulerNode targetNode)
Move reservation from one node to another
Comparing to unreserve container on source node and reserve a new
container on target node.
|
void |
FiCaSchedulerApp.nodePartitionUpdated(RMContainer rmContainer,
String oldPartition,
String newPartition) |
void |
FiCaSchedulerApp.reserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
FiCaSchedulerNode node,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Container container,
boolean reReservation) |
void |
FiCaSchedulerNode.reserveResource(SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey priority,
RMContainer container) |
boolean |
FiCaSchedulerApp.unreserve(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
FiCaSchedulerNode node,
RMContainer rmContainer) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
ReleaseContainerEvent.getContainer()
Get RMContainer.
|
RMContainer |
ContainerPreemptEvent.getContainer() |
Constructor and Description |
---|
ContainerPreemptEvent(org.apache.hadoop.yarn.api.records.ApplicationAttemptId aid,
RMContainer container,
SchedulerEventType type) |
ReleaseContainerEvent(RMContainer rmContainer)
Create Event.
|
Modifier and Type | Method and Description |
---|---|
RMContainer |
FSAppAttempt.allocate(NodeType type,
FSSchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
PendingAsk pendingAsk,
org.apache.hadoop.yarn.api.records.Container reservedContainer) |
Modifier and Type | Method and Description |
---|---|
protected void |
FSSchedulerNode.allocateContainer(RMContainer rmContainer,
boolean launchedOnNode)
The Scheduler has allocated containers on this node to the given
application.
|
protected void |
FairScheduler.completedContainerInternal(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event)
Clean up a completed container.
|
void |
FairScheduler.killContainer(RMContainer container) |
void |
FSParentQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt schedulerAttempt,
RMContainer rmContainer) |
void |
FSLeafQueue.recoverContainer(org.apache.hadoop.yarn.api.records.Resource clusterResource,
SchedulerApplicationAttempt schedulerAttempt,
RMContainer rmContainer) |
void |
FSAppAttempt.recoverContainer(SchedulerNode node,
RMContainer rmContainer) |
void |
FSSchedulerNode.reserveResource(SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer container) |
Modifier and Type | Method and Description |
---|---|
RMContainer |
FifoAppAttempt.allocate(NodeType type,
FiCaSchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
org.apache.hadoop.yarn.api.records.Container container) |
RMContainer |
FifoScheduler.getRMContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
Modifier and Type | Method and Description |
---|---|
protected void |
FifoScheduler.completedContainerInternal(RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.ContainerStatus containerStatus,
RMContainerEventType event) |
void |
FifoScheduler.killContainer(RMContainer container) |
Modifier and Type | Method and Description |
---|---|
void |
FifoOrderingPolicy.containerAllocated(S schedulableEntity,
RMContainer r) |
void |
OrderingPolicy.containerAllocated(S schedulableEntity,
RMContainer r)
Notify the
OrderingPolicy that the SchedulableEntity
has been allocated the given RMContainer , enabling the
OrderingPolicy to take appropriate action. |
abstract void |
AbstractComparatorOrderingPolicy.containerAllocated(S schedulableEntity,
RMContainer r) |
void |
FifoOrderingPolicyForPendingApps.containerAllocated(S schedulableEntity,
RMContainer r) |
void |
FifoOrderingPolicyWithExclusivePartitions.containerAllocated(S schedulableEntity,
RMContainer r) |
void |
FairOrderingPolicy.containerAllocated(S schedulableEntity,
RMContainer r) |
void |
FifoOrderingPolicy.containerReleased(S schedulableEntity,
RMContainer r) |
void |
OrderingPolicy.containerReleased(S schedulableEntity,
RMContainer r)
Notify the
OrderingPolicy that the SchedulableEntity
has released the given RMContainer , enabling the
OrderingPolicy to take appropriate action. |
abstract void |
AbstractComparatorOrderingPolicy.containerReleased(S schedulableEntity,
RMContainer r) |
void |
FifoOrderingPolicyForPendingApps.containerReleased(S schedulableEntity,
RMContainer r) |
void |
FifoOrderingPolicyWithExclusivePartitions.containerReleased(S schedulableEntity,
RMContainer r) |
void |
FairOrderingPolicy.containerReleased(S schedulableEntity,
RMContainer r) |
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.