Modifier and Type | Class and Description |
---|---|
class |
AbstractYarnScheduler<T extends SchedulerApplicationAttempt,N extends SchedulerNode> |
class |
ClusterNodeTracker<N extends SchedulerNode>
Helper library that:
- tracks the state of all cluster
SchedulerNode s
- provides convenience methods to filter and sort nodes |
Modifier and Type | Method and Description |
---|---|
<N extends SchedulerNode> |
AppSchedulingInfo.getSchedulingPlacementSet(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerkey) |
<N extends SchedulerNode> |
SchedulerApplicationAttempt.getSchedulingPlacementSet(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerRequestKey) |
Modifier and Type | Method and Description |
---|---|
SchedulerNode |
AbstractYarnScheduler.getNode(org.apache.hadoop.yarn.api.records.NodeId nodeId) |
SchedulerNode |
SchedContainerChangeRequest.getSchedulerNode() |
SchedulerNode |
YarnScheduler.getSchedulerNode(org.apache.hadoop.yarn.api.records.NodeId nodeId)
Get SchedulerNode corresponds to nodeId.
|
Modifier and Type | Method and Description |
---|---|
boolean |
NodeFilter.accept(SchedulerNode node)
Criteria to accept node in the filtered list.
|
protected void |
SchedulerApplicationAttempt.addToNewlyAllocatedContainers(SchedulerNode node,
RMContainer rmContainer) |
List<org.apache.hadoop.yarn.api.records.ResourceRequest> |
AppSchedulingInfo.allocate(NodeType type,
SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
RMContainer containerAllocated) |
boolean |
AppSchedulingInfo.checkAllocation(NodeType type,
SchedulerNode node,
org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey) |
boolean |
ContainerUpdateContext.checkAndAddToOutstandingDecreases(org.apache.hadoop.yarn.api.records.UpdateContainerRequest updateReq,
SchedulerNode schedulerNode,
org.apache.hadoop.yarn.api.records.Container container)
Add the container to outstanding decreases.
|
boolean |
ContainerUpdateContext.checkAndAddToOutstandingIncreases(RMContainer rmContainer,
SchedulerNode schedulerNode,
org.apache.hadoop.yarn.api.records.UpdateContainerRequest updateRequest)
Add the container to outstanding increases.
|
protected void |
AbstractYarnScheduler.containerIncreasedOnNode(org.apache.hadoop.yarn.api.records.ContainerId containerId,
SchedulerNode node,
org.apache.hadoop.yarn.api.records.Container increasedContainerReportedByNM) |
protected void |
AbstractYarnScheduler.containerLaunchedOnNode(org.apache.hadoop.yarn.api.records.ContainerId containerId,
SchedulerNode node) |
static boolean |
SchedulerAppUtils.isPlaceBlacklisted(SchedulerApplicationAttempt application,
SchedulerNode node,
org.apache.commons.logging.Log log) |
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 |
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) |
Constructor and Description |
---|
SchedContainerChangeRequest(RMContext rmContext,
SchedulerNode schedulerNode,
RMContainer rmContainer,
org.apache.hadoop.yarn.api.records.Resource targetCapacity) |
SchedulerNodeReport(SchedulerNode node) |
Modifier and Type | Method and Description |
---|---|
static void |
ActivitiesLogger.NODE.finishAllocatedNodeAllocation(ActivitiesManager activitiesManager,
SchedulerNode node,
org.apache.hadoop.yarn.api.records.ContainerId containerId,
AllocationState containerState) |
static void |
ActivitiesLogger.NODE.finishSkippedNodeAllocation(ActivitiesManager activitiesManager,
SchedulerNode node) |
static void |
ActivitiesLogger.APP.recordAppActivityWithAllocation(ActivitiesManager activitiesManager,
SchedulerNode node,
SchedulerApplicationAttempt application,
RMContainer updatedContainer,
ActivityState activityState) |
static void |
ActivitiesLogger.APP.recordAppActivityWithoutAllocation(ActivitiesManager activitiesManager,
SchedulerNode node,
SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.api.records.Priority priority,
String diagnostic,
ActivityState appState) |
static void |
ActivitiesLogger.QUEUE.recordQueueActivity(ActivitiesManager activitiesManager,
SchedulerNode node,
String parentQueueName,
String queueName,
ActivityState state,
String diagnostic) |
static void |
ActivitiesLogger.APP.recordRejectedAppActivityFromLeafQueue(ActivitiesManager activitiesManager,
SchedulerNode node,
SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.api.records.Priority priority,
String diagnostic) |
static void |
ActivitiesLogger.APP.recordSkippedAppActivityWithoutAllocation(ActivitiesManager activitiesManager,
SchedulerNode node,
SchedulerApplicationAttempt application,
org.apache.hadoop.yarn.api.records.Priority priority,
String diagnostic) |
Modifier and Type | Class and Description |
---|---|
class |
ContainerAllocationProposal<A extends SchedulerApplicationAttempt,N extends SchedulerNode>
Proposal to allocate/reserve a new container
|
class |
ResourceCommitRequest<A extends SchedulerApplicationAttempt,N extends SchedulerNode> |
class |
SchedulerContainer<A extends SchedulerApplicationAttempt,N extends SchedulerNode>
Contexts for a container inside scheduler
|
Modifier and Type | Class and Description |
---|---|
class |
FiCaSchedulerNode |
Modifier and Type | Class and Description |
---|---|
class |
FSSchedulerNode
Fair Scheduler specific node features.
|
Modifier and Type | Method and Description |
---|---|
void |
FSAppAttempt.recoverContainer(SchedulerNode node,
RMContainer rmContainer) |
Modifier and Type | Class and Description |
---|---|
class |
LocalitySchedulingPlacementSet<N extends SchedulerNode> |
interface |
PlacementSet<N extends SchedulerNode>
PlacementSet is the central place that decide the order of node to fit
asks by application.
|
interface |
SchedulingPlacementSet<N extends SchedulerNode>
Comparing to
PlacementSet , this also maintains
pending ResourceRequests:
- When new ResourceRequest(s) added to scheduler, or,
- Or new container allocated, scheduler can notify corresponding
PlacementSet. |
class |
SimplePlacementSet<N extends SchedulerNode>
A simple PlacementSet which keeps an unordered map
|
Modifier and Type | Method and Description |
---|---|
static <N extends SchedulerNode> |
PlacementSetUtils.getSingleNode(PlacementSet<N> ps) |
Modifier and Type | Method and Description |
---|---|
List<org.apache.hadoop.yarn.api.records.ResourceRequest> |
LocalitySchedulingPlacementSet.allocate(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
NodeType type,
SchedulerNode node) |
List<org.apache.hadoop.yarn.api.records.ResourceRequest> |
SchedulingPlacementSet.allocate(org.apache.hadoop.yarn.server.scheduler.SchedulerRequestKey schedulerKey,
NodeType type,
SchedulerNode node)
Notify container allocated.
|
boolean |
LocalitySchedulingPlacementSet.canAllocate(NodeType type,
SchedulerNode node) |
boolean |
SchedulingPlacementSet.canAllocate(NodeType type,
SchedulerNode node)
We can still have pending requirement for a given NodeType and node
|
Copyright © 2022 Apache Software Foundation. All rights reserved.