@InterfaceAudience.LimitedPrivate(value="yarn") @InterfaceStability.Evolving public interface ResourceScheduler extends YarnScheduler, Recoverable
YarnScheduler
.Modifier and Type | Method and Description |
---|---|
boolean |
attemptAllocationOnNode(SchedulerApplicationAttempt appAttempt,
org.apache.hadoop.yarn.api.records.SchedulingRequest schedulingRequest,
SchedulerNode schedulerNode)
Attempts to allocate a SchedulerRequest on a Node.
|
List<org.apache.hadoop.yarn.api.records.NodeId> |
getNodeIds(String resourceName)
Get the
NodeId available in the cluster by resource name. |
void |
reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext)
Re-initialize the
ResourceScheduler . |
void |
resetSchedulerMetrics()
Reset scheduler metrics.
|
void |
setRMContext(RMContext rmContext)
Set RMContext for
ResourceScheduler . |
addQueue, allocate, checkAccess, checkAndGetApplicationLifetime, checkAndGetApplicationPriority, getAppResourceUsageReport, getAppsInQueue, getClusterResource, getMaxClusterLevelAppPriority, getMaximumApplicationLifetime, getMaximumResourceCapability, getMaximumResourceCapability, getMinimumResourceCapability, getNodeReport, getNormalizedResource, getNumClusterNodes, getPendingResourceRequestsForAttempt, getPendingSchedulingRequestsForAttempt, getPlanQueues, getQueueInfo, getQueueUserAclInfo, getResourceCalculator, getRMContainer, getRootQueueMetrics, getSchedulerAppInfo, getSchedulerNode, getSchedulingResourceTypes, getTransferredContainers, killAllAppsInQueue, moveAllApps, moveApplication, preValidateMoveApplication, removeQueue, setClusterMaxPriority, setEntitlement, updateApplicationPriority
recover
void setRMContext(RMContext rmContext)
ResourceScheduler
.
This method should be called immediately after instantiating
a scheduler once.rmContext
- created by ResourceManagervoid reinitialize(org.apache.hadoop.conf.Configuration conf, RMContext rmContext) throws IOException
ResourceScheduler
.conf
- configurationrmContext
- RMContext.IOException
- an I/O exception has occurred.List<org.apache.hadoop.yarn.api.records.NodeId> getNodeIds(String resourceName)
NodeId
available in the cluster by resource name.resourceName
- resource nameNodeId
by resource name.boolean attemptAllocationOnNode(SchedulerApplicationAttempt appAttempt, org.apache.hadoop.yarn.api.records.SchedulingRequest schedulingRequest, SchedulerNode schedulerNode)
appAttempt
- ApplicationAttempt.schedulingRequest
- SchedulingRequest.schedulerNode
- SchedulerNode.void resetSchedulerMetrics()
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.