Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 

A

about() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
AboutBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
AboutPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
AboutPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.AboutPage
 
absoluteCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
absoluteMaxCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
absoluteUsedCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
absorb(AllocationTagsManager.TypeToCountedTags<T>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager.TypeToCountedTags
Absorbs the given AllocationTagsManager.TypeToCountedTags to current mapping, this will aggregate the count of the tags with same name.
AbstractAutoCreatedLeafQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Abstract class for dynamic auto created queues managed by an implementation of AbstractManagedParentQueue
AbstractAutoCreatedLeafQueue(CapacitySchedulerContext, String, AbstractManagedParentQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractAutoCreatedLeafQueue
 
AbstractAutoCreatedLeafQueue(CapacitySchedulerContext, CapacitySchedulerConfiguration, String, AbstractManagedParentQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractAutoCreatedLeafQueue
 
AbstractComparatorOrderingPolicy<S extends SchedulableEntity> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
An OrderingPolicy which can serve as a baseclass for policies which can be expressed in terms of comparators
AbstractComparatorOrderingPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
AbstractContainerAllocator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator
For an application, resource limits and resource requests, decide how to allocate container.
AbstractContainerAllocator(FiCaSchedulerApp, ResourceCalculator, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.AbstractContainerAllocator
 
AbstractContainerAllocator(FiCaSchedulerApp, ResourceCalculator, RMContext, ActivitiesManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.AbstractContainerAllocator
 
AbstractCSQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
AbstractCSQueue(CapacitySchedulerContext, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
AbstractCSQueue(CapacitySchedulerContext, CapacitySchedulerConfiguration, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
AbstractCSQueue.CapacityConfigType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
AbstractManagedParentQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
A container class for automatically created child leaf queues.
AbstractManagedParentQueue(CapacitySchedulerContext, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
AbstractPlacementProcessor - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
Base class for all PlacementProcessors.
AbstractPlacementProcessor() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.AbstractPlacementProcessor
 
AbstractPreemptableResourceCalculator - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Calculate how much resources need to be preempted for each queue, will be used by PreemptionCandidatesSelector.
AbstractPreemptableResourceCalculator(CapacitySchedulerPreemptionContext, boolean, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptableResourceCalculator
PreemptableResourceCalculator constructor.
AbstractPreemptionEntity - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Abstract temporary data-structure for tracking resource availability,pending resource need, current utilization for app/queue.
AbstractReservationSystem - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This is the implementation of ReservationSystem based on the ResourceScheduler
AbstractReservationSystem(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
Construct the service.
AbstractResourceUsage - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
This class can be used to track resource usage in queue/user/app.
AbstractResourceUsage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
AbstractResourceUsage.ResourceType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Use enum here to make implementation more cleaner and readable.
AbstractResourceUsage.UsageByLabel - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
UsageByLabel stores resource array for all resource usage types.
AbstractSchedulerPlanFollower - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
 
AbstractSchedulerPlanFollower() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
AbstractSystemMetricsPublisher - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
Abstract implementation of SystemMetricsPublisher which is then extended by metrics publisher implementations depending on timeline service version.
AbstractSystemMetricsPublisher(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher
 
AbstractSystemMetricsPublisher.MultiThreadedDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
Dispatches ATS related events using multiple threads.
AbstractSystemMetricsPublisher.SystemMetricsEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.metrics
EventType which is used while publishing the events.
AbstractSystemMetricsPublisher.TimelinePublishEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
TimelinePublishEvent's hash code should be based on application's id this will ensure all the events related to a particular app goes to particular thread of MultiThreaded dispatcher.
AbstractUsersManager - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
AbstractUsersManager tracks users in the system.
AbstractYarnScheduler<T extends SchedulerApplicationAttempt,N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
AbstractYarnScheduler(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Construct the service.
accept(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
accept(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
 
accept(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
accept(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
accept(SchedulerNode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeFilter
Criteria to accept node in the filtered list.
acceptedByLocality(ResourceCalculator, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
This method is visible to allow sub-classes to override the behavior, specifically to take into account locality-based limitations of how much the queue can consumed.
ACCESSIBLE_NODE_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
accessibleNodeLabels - Variable in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager.Queue
 
accessibleToPartition(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
activateApp(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
activateApplication(String, ApplicationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractUsersManager
An application has new outstanding requests.
activateApplication(String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
An application has new outstanding requests.
activateApplication(String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
activateApplication() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
activateApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
activateNextMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
activateNextMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
Activate the new master-key
activateNextMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
Activate the new master-key
activateNode(NodeId, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
activateQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueStateManager
Active the queue.
activeQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
activeQueue() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueue
Active the queue.
activeServices - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
"Active" services.
ActiveStandbyElectorBasedElectorService - Class in org.apache.hadoop.yarn.server.resourcemanager
Leader election implementation that uses ActiveStandbyElector.
ActiveUsersManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
ActiveUsersManager tracks active users in the system.
ActiveUsersManager(QueueMetrics) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
 
ActivitiesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ActivitiesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
ActivitiesInfo(String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
ActivitiesInfo(List<NodeAllocation>, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
ActivitiesLogger - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
Utility for logging scheduler activities
ActivitiesLogger() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger
 
ActivitiesLogger.APP - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
Methods for recording activities from an app
ActivitiesLogger.NODE - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
Methods for recording overall activities from one node update
ActivitiesLogger.QUEUE - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
Methods for recording activities from a queue
activitiesManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
ActivitiesManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
A class to store node or application allocations.
ActivitiesManager(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
activitiesManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
ActivityDiagnosticConstant - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
ActivityDiagnosticConstant() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
ActivityNode - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
ActivityNode(String, String, String, ActivityState, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
ActivityNodeInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ActivityState - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
add(AppAttemptInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptsInfo
 
add(StatisticsItemInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationStatisticsInfo
 
add(AppInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppsInfo
 
add(AppTimeoutInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutsInfo
 
add(NodeInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodesInfo
 
add(PartitionQueueCapacitiesInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
ADD_NODE_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#addToClusterNodeLabels.
addAll(ArrayList<AppInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppsInfo
 
addAll(ArrayList<NodeInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodesInfo
 
addAll(List<ResourceInformation>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInformationsInfo
 
addAllApps(Collection<TempAppPerPartition>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
addAllocate(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
addAllocationActivity(String, String, String, ActivityState, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
addAllocationDetails(RMContainer, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
addAllocationTag(AllocationTagInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagsInfo
 
addAllSchedulableEntities(Collection<S>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
addAllSchedulableEntities(Collection<S>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Add a collection of SchedulableEntity objects to be managed for allocation and preemption ordering.
addAMLaunchDelay(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
addAMRegisterDelay(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
addAppAllocationActivity(String, String, ActivityState, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
addAppAttemptFirstContainerAllocationDelay(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
addApplication(ApplicationId, String, String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Add a new application to the scheduler, with a given id, queue name, and user.
addApplication(ApplicationId, String, String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
addApplicationAsync(ApplicationId, Credentials, boolean, String, Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
Asynchronously add application tokens for renewal.
addApplicationAsyncDuringRecovery(ApplicationId, Credentials, boolean, String, Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
Asynchronously add application tokens for renewal.
addApplicationAttempt(ApplicationAttemptId, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Add a new application attempt to the scheduler.
addApplicationAttempt(ApplicationAttemptId, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
addApplicationHomeSubCluster(AddApplicationHomeSubClusterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
addApplicationSync(ApplicationId, Credentials, boolean, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
addChild(TempQueuePerPartition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
When adding a child we also aggregate its pending resource needs.
addChild(ActivityNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
addChildQueue(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
Add the specified child queue.
addChildQueue(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
addCommitFailure(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
addCommitSuccess(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
addConstraint(ApplicationId, Set<String>, PlacementConstraint, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
addConstraint(ApplicationId, Set<String>, PlacementConstraint, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Add a placement constraint for a given application and a given set of (source) allocation tags.
addContainer(NodeId, ContainerId, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Notify container allocated on a node.
AddContainersToBeRemovedFromNMTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.AddContainersToBeRemovedFromNMTransition
 
addContinuousSchedulingRunDuration(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSOpDurations
Deprecated.
addGlobalConstraint(Set<String>, PlacementConstraint, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
addGlobalConstraint(Set<String>, PlacementConstraint, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Add a placement constraint that will be used globally.
addInterval(ReservationInterval, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Add resource for the specified interval.
addInterval(ReservationInterval, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Add a resource for the specified interval.
ADDITIONAL_RESOURCE_BALANCE_BASED_ON_RESERVED_CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
By default, reserved resource will be excluded while balancing capacities of queues.
addKillableContainer(KillableContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
addLabelsToNode(Map<NodeId, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
addMissedNonPartitionedRequestSchedulingOpportunity(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addNode(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.blacklist.BlacklistManager
Report failure of a container on node.
addNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.blacklist.DisabledBlacklistManager
 
addNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.blacklist.SimpleBlacklistManager
 
addNode(List<NMContainerStatus>, RMNode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.ClusterMonitor
 
addNode(N) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
addNode(List<NMContainerStatus>, RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
AddNodeTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.AddNodeTransition
 
addNodeUpdate(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
addNodeUpdateDuration(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSOpDurations
 
addPartitionToUnderServedQueues(String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
addPartitionToUnderServedQueues(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
addPersistedPassword(Token<AMRMTokenIdentifier>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Populate persisted password of AMRMToken back to AMRMTokenSecretManager.
addPrioirityACLs(List<AppPriorityACLGroup>, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AppPriorityACLsManager
Each Queue could have configured with different priority acl's groups.
addQueue(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
addQueue(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
addQueue(String, CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
addQueue(String, T) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueueManager
Add a new queue to the existing queues.
addQueue(Queue) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Add to the scheduler a new Queue.
addRequestedPartition(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
addReReservation(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addReservation(ReservationAllocation, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
addReservation(ReservationAllocation, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanEdit
Add a new ReservationAllocation to the plan.
addReservationDetails(RMContainer, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
addReservationQueue(String, Queue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Add a new reservation queue for reservation currResId for this planQueue.
addReservationQueue(String, Queue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
addReservationQueue(String, Queue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
addRMContainer(ContainerId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addSchedulableEntity(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
addSchedulableEntity(S) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Add a SchedulableEntity to be managed for allocation and preemption ordering.
addSchedulingOpportunity(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addTags(NodeId, ApplicationId, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
 
addToBatch(SchedulingRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Add a Scheduling request to the batch.
addToBeRemovedIncreaseRequest(SchedContainerChangeRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
addToBlacklist(Set<String>, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
 
addToCache(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
addToCluserNodeLabels(Collection<NodeLabel>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
addToClusterNodeLabels(AddToClusterNodeLabelsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
addToClusterNodeLabels(NodeLabelsInfo, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method adds specific node labels for specific nodes, and it is reachable by using RMWSConsts.ADD_NODE_LABELS.
addToClusterNodeLabels(NodeLabelsInfo, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
addToNewlyAllocatedContainers(SchedulerNode, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addToNewlyDecreasedContainers(ContainerId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addToNewlyDemotedContainers(ContainerId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addToPreemptMap(Map<ApplicationAttemptId, Set<RMContainer>>, Map<ApplicationAttemptId, Set<RMContainer>>, ApplicationAttemptId, RMContainer) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionUtils
 
addToQueueInfoList(CapacitySchedulerQueueInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
addToQueueInfoList(FairSchedulerQueueInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfoList
 
addToUpdateContainerErrors(UpdateContainerError) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
addUpdateThreadRunDuration(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSOpDurations
 
addUserPerPartition(String, TempUserPerPartition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
AdminService - Class in org.apache.hadoop.yarn.server.resourcemanager
 
AdminService(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
adminService - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
AggregateAppResourceUsage - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
AggregateAppResourceUsage(Map<String, Long>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AggregateAppResourceUsage
 
aggregatedContainersPhysicalMemoryMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
aggregatedContainersVirtualMemoryMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
aggregateLogReport(NodeId, LogAggregationReport) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
AlignedPlannerWithGreedy - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
A planning algorithm that first runs LowCostAligned, and if it fails runs Greedy.
AlignedPlannerWithGreedy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
All() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.All
 
ALL_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser
 
ALL_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
ALLOC_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
ALLOC_RELOAD_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
Time to wait between checks of the allocation file
ALLOC_RELOAD_WAIT_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
Time to wait after the allocation has been modified before reloading it (this is done to prevent loading a file that hasn't been fully written).
allocate(AllocateRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
allocate(NodeType, SchedulerNode, SchedulerRequestKey, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<SchedulingRequest>, List<ContainerId>, List<String>, List<String>, ContainerUpdates) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
allocate(FiCaSchedulerNode, SchedulerRequestKey, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
allocate(ApplicationAttemptId, AllocateRequest, AllocateResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.DisabledPlacementProcessor
 
allocate(ApplicationAttemptId, AllocateRequest, AllocateResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.PlacementConstraintProcessor
 
allocate(ApplicationAttemptId, AllocateRequest, AllocateResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.SchedulerPlacementProcessor
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<SchedulingRequest>, List<ContainerId>, List<String>, List<String>, ContainerUpdates) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
allocate(NodeType, FSSchedulerNode, SchedulerRequestKey, PendingAsk, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
allocate(NodeType, FiCaSchedulerNode, SchedulerRequestKey, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoAppAttempt
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<SchedulingRequest>, List<ContainerId>, List<String>, List<String>, ContainerUpdates) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
allocate(SchedulerRequestKey, NodeType, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Notify container allocated.
allocate(SchedulerRequestKey, NodeType, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
allocate(SchedulerRequestKey, NodeType, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<SchedulingRequest>, List<ContainerId>, List<String>, List<String>, ContainerUpdates) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
The main api between the ApplicationMaster and the Scheduler.
allocateContainer(RMContainer, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
allocateContainer(RMContainer, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
The Scheduler has allocated containers on this node to the given application.
allocateContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
The Scheduler has allocated containers on this node to the given application.
allocateContainer(RMContainer, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
The Scheduler has allocated containers on this node to the given application.
allocatedContainerId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
allocatedContainerId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeAllocationInfo
 
allocatedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
allocatedMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
allocatedVirtualCores - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
allocateForDistributedScheduling(DistributedSchedulingAllocateRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
allocateResources(String, String, int, Resource, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
allocateResources(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Allocate Resource for container size change.
AllocateResponseLock(AllocateResponse) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService.AllocateResponseLock
 
allocateUser(ReservationId, String, Plan, ReservationDefinition, ReservationAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
Performs the actual allocation for a ReservationDefinition within a Plan.
Allocation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
Allocation(List<Container>, Resource, Set<ContainerId>, Set<ContainerId>, List<ResourceRequest>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
Allocation(List<Container>, Resource, Set<ContainerId>, Set<ContainerId>, List<ResourceRequest>, List<NMToken>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
Allocation(List<Container>, Resource, Set<ContainerId>, Set<ContainerId>, List<ResourceRequest>, List<NMToken>, List<Container>, List<Container>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
Allocation(List<Container>, Resource, Set<ContainerId>, Set<ContainerId>, List<ResourceRequest>, List<NMToken>, List<Container>, List<Container>, List<Container>, List<Container>, List<Container>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
ALLOCATION_FILE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
AllocationActivity - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
AllocationActivity(String, String, String, ActivityState, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AllocationActivity
 
allocationAttempt - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
AllocationConfiguration - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
AllocationConfiguration(QueueProperties, AllocationFileParser, QueuePlacementPolicy, ReservationQueueConfiguration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
AllocationConfiguration(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
AllocationConfigurationException - Exception in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Thrown when the allocation file for QueueManager is malformed.
AllocationConfigurationException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfigurationException
 
AllocationConfigurationException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfigurationException
 
AllocationExpirationInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
AllocationExpirationInfo(ContainerId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
AllocationExpirationInfo(ContainerId, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
AllocationFileLoaderService - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
AllocationFileLoaderService() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
AllocationFileLoaderService(Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
AllocationFileLoaderService.Listener - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
AllocationFileParser - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation
Responsible for parsing allocation.xml config file.
AllocationFileParser(NodeList) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
AllocationFileQueueParser - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation
Responsible for loading queue configuration properties from a list of Elements containing queues.
AllocationFileQueueParser(List<Element>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileQueueParser
 
allocations - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
allocations - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
AllocationState - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
AllocationState - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator
 
allocationState - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivityNodeInfo
 
allocationState - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
allocationTagExistsOnNode(NodeId, ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Check if given tag exists on node.
AllocationTagInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
DAO object to display node allocation tag.
AllocationTagInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagInfo
 
AllocationTagInfo(String, long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagInfo
 
AllocationTags - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Allocation tags under same namespace.
AllocationTagsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
DAO object to display node allocation tags.
AllocationTagsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagsInfo
 
AllocationTagsManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
In-memory mapping between applications/container-tags and nodes/racks.
AllocationTagsManager(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
 
AllocationTagsManager.TypeToCountedTags<T> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Generic store mapping type T to counted tags.
ALLOW_UNDECLARED_POOLS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether pools can be created that were not specified in the FS configuration file
allowed - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
AM_ALLOCATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
AM_CLIENT_TOKEN_MASTER_KEY_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
AM_CONTAINER_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
AM_RM_TOKEN_SERVICE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
amContainerLogs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
amContainerLogsExist - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
amContainerLogsExist() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
amHostHttpAddress - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AMLauncher - Class in org.apache.hadoop.yarn.server.resourcemanager.amlauncher
The launch of the AM itself.
AMLauncher(RMContext, RMAppAttempt, AMLauncherEventType, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
AMLauncherEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.amlauncher
 
AMLauncherEvent(AMLauncherEventType, RMAppAttempt) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncherEvent
 
AMLauncherEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.amlauncher
 
AMLivelinessMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
AMLivelinessMonitor(Dispatcher) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AMLivelinessMonitor
 
AMLivelinessMonitor(Dispatcher, Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AMLivelinessMonitor
 
amNodeLabelExpression - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AMResourceLimit - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
AMResourceUsed - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
AMRMTOKEN_SECRET_MANAGER_NODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
AMRMTOKEN_SECRET_MANAGER_ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
AMRMTokenSecretManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
AMRM-tokens are per ApplicationAttempt.
AMRMTokenSecretManager(Configuration, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
AMRMTokenSecretManagerState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
Contains all the state data that needs to be stored persistently for AMRMTokenSecretManager
AMRMTokenSecretManagerState() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
 
AMRMTokenSecretManagerStatePBImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb
 
AMRMTokenSecretManagerStatePBImpl() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
AMRMTokenSecretManagerStatePBImpl(YarnServerResourceManagerRecoveryProtos.AMRMTokenSecretManagerStateProto) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
amUsed - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
ANY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
anythingAllocatedOrReserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
APP() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
app - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppsInfo
 
app() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
APP_FAIL_FAST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
APP_ID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
APP_SKIPPED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
Skip the application, and look at other applications of the same queue
APP_STATISTICS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppStatistics.
appACLsUpdated(RMApp, String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appACLsUpdated(RMApp, String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appACLsUpdated(RMApp, String, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appACLsUpdated(RMApp, String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appACLsUpdated(RMApp, String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
AppActivitiesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppActivitiesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
AppActivitiesInfo(String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
AppActivitiesInfo(List<AppAllocation>, ApplicationId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
AppAddedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
AppAddedSchedulerEvent(ApplicationId, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
AppAddedSchedulerEvent(ApplicationId, String, String, ApplicationPlacementContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
AppAddedSchedulerEvent(ApplicationId, String, String, ReservationId, Priority) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
AppAddedSchedulerEvent(String, ApplicationSubmissionContext, boolean, Priority) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
AppAddedSchedulerEvent(String, ApplicationSubmissionContext, boolean, Priority, ApplicationPlacementContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
AppAddedSchedulerEvent(ApplicationId, String, String, boolean, ReservationId, Priority, ApplicationPlacementContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
AppAllocation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
AppAllocation(Priority, NodeId, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
AppAllocationInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
appAMNodePartitionName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
appattempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
AppAttemptAddedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
AppAttemptAddedSchedulerEvent(ApplicationAttemptId, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptAddedSchedulerEvent
 
AppAttemptAddedSchedulerEvent(ApplicationAttemptId, boolean, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptAddedSchedulerEvent
 
appAttemptFinished(RMAppAttempt, RMAppAttemptState, RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appAttemptFinished(RMAppAttempt, RMAppAttemptState, RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appAttemptFinished(RMAppAttempt, RMAppAttemptState, RMApp, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appAttemptFinished(RMAppAttempt, RMAppAttemptState, RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appAttemptFinished(RMAppAttempt, RMAppAttemptState, RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
appAttemptId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
APPATTEMPTID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
AppAttemptInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppAttemptInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
AppAttemptInfo(ResourceManager, RMAppAttempt, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
AppAttemptPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
AppAttemptPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppAttemptPage
 
appAttemptRegistered(RMAppAttempt, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appAttemptRegistered(RMAppAttempt, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appAttemptRegistered(RMAppAttempt, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appAttemptRegistered(RMAppAttempt, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appAttemptRegistered(RMAppAttempt, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
AppAttemptRemovedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
AppAttemptRemovedSchedulerEvent(ApplicationAttemptId, RMAppAttemptState, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptRemovedSchedulerEvent
 
APPATTEMPTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
AppAttemptsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppAttemptsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptsInfo
 
appCreated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appCreated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appCreated(RMApp, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appCreated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appCreated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
append(RMAuditLogger.Keys, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.ArgsBuilder
 
appFinished(RMApp, RMAppState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appFinished(RMApp, RMAppState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appFinished(RMApp, RMAppState, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appFinished(RMApp, RMAppState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appFinished(RMApp, RMAppState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
appFinished() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
AppID(ApplicationId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.AppID
 
APPID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
appIdNum - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AppInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AppInfo(ResourceManager, RMApp, Boolean, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AppInfo(ResourceManager, RMApp, Boolean, String, DeSelectFields) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
APPLICATION_DO_NOT_NEED_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
APPLICATION_PRIORITY_DO_NOT_NEED_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
APPLICATION_TAGS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
APPLICATION_TYPES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
applicationACLsManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ApplicationAttemptEventDispatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.ApplicationAttemptEventDispatcher
 
applicationAttemptFinished(RMAppAttempt, RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
applicationAttemptStarted(RMAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
ApplicationAttemptStateData - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
 
ApplicationAttemptStateData() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
ApplicationAttemptStateDataPBImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb
 
ApplicationAttemptStateDataPBImpl() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
ApplicationAttemptStateDataPBImpl(YarnServerResourceManagerRecoveryProtos.ApplicationAttemptStateDataProto) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
ApplicationEventDispatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.ApplicationEventDispatcher
 
applicationFinished(RMApp, RMAppState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
applicationFinished(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
Removing delegation token for completed applications.
applicationId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
applicationId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
applicationMasterFinished(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
ApplicationMasterLauncher - Class in org.apache.hadoop.yarn.server.resourcemanager.amlauncher
 
ApplicationMasterLauncher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
ApplicationMasterService - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ApplicationMasterService(RMContext, YarnScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
ApplicationMasterService(String, RMContext, YarnScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
ApplicationMasterService.AllocateResponseLock - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ApplicationPlacementAllocatorFactory - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Factory class to build various application placement policies.
ApplicationPlacementAllocatorFactory() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ApplicationPlacementAllocatorFactory
 
ApplicationPlacementContext - Class in org.apache.hadoop.yarn.server.resourcemanager.placement
Each placement rule when it successfully places an application onto a queue returns a PlacementRuleContext which encapsulates the queue the application was mapped to and any parent queue for the queue (if configured)
ApplicationPlacementContext(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext
 
ApplicationPlacementContext(String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext
 
applications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
ApplicationSchedulingConfig - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
This class will keep all Scheduling env's names which will help in placement calculations.
ApplicationSchedulingConfig() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ApplicationSchedulingConfig
 
applicationSchedulingEnvs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
ApplicationsRequestBuilder - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
applicationStarted(RMApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
ApplicationStateData - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
Contains all the state data that needs to be stored persistently for an Application
ApplicationStateData() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
ApplicationStateDataPBImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb
 
ApplicationStateDataPBImpl() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
ApplicationStateDataPBImpl(YarnServerResourceManagerRecoveryProtos.ApplicationStateDataProto) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
ApplicationStatisticsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ApplicationStatisticsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationStatisticsInfo
 
ApplicationSubmissionContextInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class to allow users to send information required to create an ApplicationSubmissionContext which can then be used to submit an app
ApplicationSubmissionContextInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
applicationTags - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
applicationType - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AppLogAggregationStatusPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
AppLogAggregationStatusPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppLogAggregationStatusPage
 
apply(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
 
apply(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
apply(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
apply(Resource, ResourceCommitRequest<FiCaSchedulerApp, FiCaSchedulerNode>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
appNodeLabelExpression - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AppPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
AppPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppPage
 
AppPlacementAllocator<N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
This class has the following functionality: 1) Keeps track of pending resource requests when following events happen: - New ResourceRequests are added to scheduler.
AppPlacementAllocator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
 
appPriority - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivityNodeInfo
 
appPriority - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
AppPriority - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppPriority() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppPriority
 
AppPriority(int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppPriority
 
AppPriorityACLConfigurationParser - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
PriorityACLConfiguration class is used to parse Application Priority ACL configuration from capcity-scheduler.xml
AppPriorityACLConfigurationParser() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser
 
AppPriorityACLConfigurationParser.AppPriorityACLKeyType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
AppPriorityACLGroup - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
PriorityACLGroup will hold all ACL related information per priority.
AppPriorityACLGroup(Priority, Priority, AccessControlList) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
AppPriorityACLGroup() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
AppPriorityACLsManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
Manager class to store and check permission for Priority ACLs.
AppPriorityACLsManager(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.AppPriorityACLsManager
 
AppQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppQueue() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppQueue
 
AppQueue(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppQueue
 
AppRemovedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
AppRemovedSchedulerEvent(ApplicationId, RMAppState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppRemovedSchedulerEvent
 
APPS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getApps and RMWebServiceProtocol#getApp.
APPS_APPID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getApp.
APPS_APPID_APPATTEMPTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppAttempts.
APPS_APPID_APPATTEMPTS_APPATTEMPTID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for WebServices#getAppAttempt.
APPS_APPID_APPATTEMPTS_APPATTEMPTID_CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for WebServices#getContainers.
APPS_APPID_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppPriority and RMWebServiceProtocol#updateApplicationPriority.
APPS_APPID_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppQueue and RMWebServiceProtocol#updateAppQueue.
APPS_APPID_STATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppState and RMWebServiceProtocol#updateAppState.
APPS_NEW_APPLICATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#createNewApplication.
APPS_TIMEOUT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#updateApplicationTimeout.
APPS_TIMEOUTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppTimeouts.
APPS_TIMEOUTS_TYPE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppTimeout.
AppSchedulingInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
This class keeps track of all the consumption of an application.
AppSchedulingInfo(ApplicationAttemptId, String, Queue, AbstractUsersManager, long, ResourceUsage, Map<String, String>, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
appSchedulingInfo - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
 
appSchedulingInfo - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
appsCompleted - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
appsFailed - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
AppsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppsInfo
 
appsKilled - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
appsPending - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
appsRunning - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
appsSubmitted - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
AppState - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppState() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppState
 
AppState(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppState
 
appStateUpdated(RMApp, YarnApplicationState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appStateUpdated(RMApp, YarnApplicationState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appStateUpdated(RMApp, YarnApplicationState, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appStateUpdated(RMApp, YarnApplicationState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appStateUpdated(RMApp, YarnApplicationState, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
AppTag(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.AppTag
 
AppTimeoutInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
DAO object to display Application timeout information.
AppTimeoutInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
AppTimeoutsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
This class hosts a set of AppTimeout DAO objects.
AppTimeoutsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutsInfo
 
appUpdated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
appUpdated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
appUpdated(RMApp, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
appUpdated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
appUpdated(RMApp, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
archiveCompletedReservations(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
archiveCompletedReservations(long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanEdit
Method invoked to garbage collect old reservations.
areActiveServicesRunning() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ArgsBuilder() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.ArgsBuilder
 
ASSIGN_MULTIPLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether to assign multiple containers in one check-in.
ASSIGN_MULTIPLE_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
assignAppToQueue(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementPolicy
Applies this rule to an app with the given requested queue and user/group information.
assignAppToQueue(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
 
assignAppToQueue(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Reject
 
assignContainer(FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
assignContainer(FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
assignContainer(FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
assignContainer(FSSchedulerNode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Assign a container on this node if possible, and return the amount of resources assigned.
assignContainers(Resource, FiCaSchedulerNode, ResourceLimits, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, SchedulingMode, ResourceLimits, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.AbstractContainerAllocator
allocate needs to handle following stuffs: Select request: Select a request to allocate.
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, SchedulingMode, ResourceLimits, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocator
 
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, SchedulingMode, ResourceLimits, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.RegularContainerAllocator
 
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, ResourceLimits, SchedulingMode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Assign containers to applications in the queue or it's children (if any).
assignContainers(Resource, FiCaSchedulerNode, ResourceLimits, SchedulingMode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
 
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, ResourceLimits, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, ResourceLimits, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
assignContainers(Resource, CandidateNodeSet<FiCaSchedulerNode>, ResourceLimits, SchedulingMode, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
AssignmentDetails(RMContainer, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation.AssignmentDetails
 
AssignmentInformation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
 
AssignmentInformation() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
AssignmentInformation.AssignmentDetails - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
 
AssignmentInformation.Operation - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
 
assignMultiple - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
assignPreemption(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
assignPreemption(float, ResourceCalculator, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
asyncContainerRelease(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
To be used to release a container via a Scheduler Event rather than in the same thread.
attachContainer(Resource, FiCaSchedulerApp, RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Attach a container to this queue
attachContainer(Resource, FiCaSchedulerApp, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
attachContainer(Resource, FiCaSchedulerApp, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
attempt - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptsInfo
 
attemptAllocationOnNode(SchedulerApplicationAttempt, SchedulingRequest, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Default implementation.
attemptAllocationOnNode(SchedulerApplicationAttempt, SchedulingRequest, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
attemptAllocationOnNode(SchedulerApplicationAttempt, SchedulingRequest, SchedulerNode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler
Attempts to allocate a SchedulerRequest on a Node.
attemptId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
attemptOpportunisticResourceUsage - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Resource usage of opportunistic containers.
attemptResourceUsage - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
attemptResourceUsageAllocatedRemotely - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Scheduled by a remote scheduler.
attempts - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
ATTEMPTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
AuditConstants() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
authorizer - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
AUTO_CREATE_CHILD_QUEUE_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
AUTO_CREATE_QUEUE_MAX_QUEUES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
AUTO_CREATED_LEAF_QUEUE_TEMPLATE_PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
AUTO_CREATED_QUEUE_MANAGEMENT_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
AutoCreatedLeafQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Leaf queues which are auto created by an underlying implementation of AbstractManagedParentQueue.
AutoCreatedLeafQueue(CapacitySchedulerContext, String, ManagedParentQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueue
 
AutoCreatedLeafQueueConfig - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Auto Created Leaf queue configurations, capacity
AutoCreatedLeafQueueConfig(AutoCreatedLeafQueueConfig.Builder) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig
 
AutoCreatedLeafQueueConfig.Builder - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
AutoCreatedQueueManagementPolicy - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
availableResource - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
availableResources(RLESparseResourceAllocation, Plan, String, ReservationId, long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityOverTimePolicy
 
availableResources(RLESparseResourceAllocation, Plan, String, ReservationId, long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.NoOverCommitPolicy
 
availableResources(RLESparseResourceAllocation, Plan, String, ReservationId, long, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.SharingPolicy
This method provide a (partial) instantaneous validation by applying business rules (such as max number of parallel containers allowed for a user).
availableVirtualCores - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
availMemoryMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
availNodeCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
AVERAGE_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 

B

baseEpoch - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
BatchedRequests - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
A grouping of Scheduling Requests which are sent to the PlacementAlgorithm to place as a batch.
BatchedRequests(BatchedRequests.IteratorType, ApplicationId, Collection<SchedulingRequest>, int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
 
BatchedRequests.IteratorType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
Iterator Type.
becomeActive() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
becomeStandby() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
blacklistedNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
BlacklistManager - Interface in org.apache.hadoop.yarn.server.resourcemanager.blacklist
Tracks blacklists based on failures reported on nodes.
build() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig.Builder
 
build() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
build() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
Builder() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig.Builder
 
buildStateProto(ReservationAllocation) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 

C

CachedResolver(Clock, int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
calcCostOfInterval(long, long, RLESparseResourceAllocation, RLESparseResourceAllocation, Resource, ResourceCalculator, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
calcCostOfLoad(Resource, Resource, ResourceCalculator) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
calcCostOfTimeSlot(long, RLESparseResourceAllocation, RLESparseResourceAllocation, Resource, ResourceCalculator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
calculateAndGetAMResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
calculateAndGetAMResourceLimitPerPartition(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
calcWeight(ReservationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalByDemand
 
canAllocate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
canAllocate(NodeType, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
We can still have pending requirement for a given NodeType and node
canAllocate(NodeType, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
canAllocate(NodeType, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
canAppBeRunnable(FSQueue, FSAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Checks whether making the application runnable would exceed any maxRunningApps limits.
canAssignToUser(Resource, String, Resource, FiCaSchedulerApp, String, ResourceLimits) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
cancelDelegationToken(CancelDelegationTokenRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
cancelDelegationToken(HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method cancel the delegation token from the client, and it is reachable by using RMWSConsts.DELEGATION_TOKEN.
cancelDelegationToken(HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
cancelTimer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
canDelayTo(SchedulerRequestKey, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
Can delay to next?.
canDelayTo(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Can delay to give locality? TODO: This should be moved out of AppPlacementAllocator and should belong to specific delay scheduling policy impl.
canDelayTo(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
canDelayTo(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
canDelete(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueStateManager
Whether this queue can be deleted.
CandidateNodeSet<N extends SchedulerNode> - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
A group of nodes which can be allocated by scheduler.
CandidateNodeSetUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
Utility methods for CandidateNodeSet.
canRunAppAM(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
Check whether this queue can run the Application Master under the maxAMShare limit.
canSatisfyConstraints(ApplicationId, SchedulingRequest, SchedulerNode, PlacementConstraintManager, AllocationTagsManager) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintsUtil
Returns true if the placement constraint for a given scheduling request is currently satisfied by the specific scheduler node.
capacities(QueueCapacities) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig.Builder
 
capacities - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
capacities - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
capacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
capacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
capacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
capacityConfigType - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
CapacityHeadroomProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
CapacityHeadroomProvider(UsersManager.User, LeafQueue, FiCaSchedulerApp, LeafQueue.QueueResourceLimitsInfo) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityHeadroomProvider
 
CapacityOverTimePolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This policy enforces a time-extended notion of Capacity.
CapacityOverTimePolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityOverTimePolicy
 
CapacityReservationSystem - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This is the implementation of ReservationSystem based on the CapacityScheduler
CapacityReservationSystem() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
CapacityScheduler - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
CapacityScheduler() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
CapacitySchedulerConfiguration - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
CapacitySchedulerConfiguration() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
CapacitySchedulerConfiguration(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
CapacitySchedulerConfiguration(Configuration, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
CapacitySchedulerConfiguration.AbsoluteResourceType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Different resource types supported.
CapacitySchedulerContext - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Read-only interface to CapacityScheduler context.
CapacitySchedulerHealthInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerHealthInfo.LastRunDetails - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerHealthInfo.OperationInformation - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
CapacitySchedulerInfo(CSQueue, CapacityScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
CapacitySchedulerLeafQueueInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Metrics for capacity scheduler.
CapacitySchedulerMetrics() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
CapacitySchedulerPlanFollower - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This class implements a PlanFollower.
CapacitySchedulerPlanFollower() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
CapacitySchedulerPreemptionContext - Interface in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
This interface provides context for the calculation of ideal allocation and preemption for the CapacityScheduler.
CapacitySchedulerPreemptionUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
 
CapacitySchedulerPreemptionUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionUtils
 
CapacitySchedulerQueueInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerQueueInfoList - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CapacitySchedulerQueueInfoList() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
CapacitySchedulerQueueManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Context of the Queues in Capacity Scheduler.
CapacitySchedulerQueueManager(Configuration, RMNodeLabelsManager, AppPriorityACLsManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
Construct the service.
CHANGE_CONTAINER_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
CHECK_USER_ACCESS_TO_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for {code checkUserAccessToQueue#}
checkAbsoluteCapacity(String, float, float) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
 
checkAccess(UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
checkAccess(UserGroupInformation, QueueACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
checkAccess(UserGroupInformation, QueueACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
checkAccess(UserGroupInformation, QueueACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
checkAccess(UserGroupInformation, QueueACL, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Check if the user has permission to perform the operation.
checkAccess(UserGroupInformation, String, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AppPriorityACLsManager
Priority based checkAccess to ensure that given user has enough permission to submit application at a given priority level.
checkAccess(UserGroupInformation, QueueACL, RMApp, String, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.QueueACLsManager
 
checkAccess(UserGroupInformation, QueueACL, RMApp, String, List<String>, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.QueueACLsManager
Check access to a targetQueue in the case of a move of an application.
checkAccess(UserGroupInformation, ReservationACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ReservationsACLsManager
 
checkAllocation(NodeType, SchedulerNode, SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
checkAndAddToOutstandingDecreases(UpdateContainerRequest, SchedulerNode, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
Add the container to outstanding decreases.
checkAndAddToOutstandingIncreases(RMContainer, SchedulerNode, UpdateContainerRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
Add the container to outstanding increases.
checkAndGetApplicationLifetime(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
checkAndGetApplicationLifetime(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
checkAndGetApplicationLifetime(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
checkAndGetApplicationLifetime(String, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Verify whether a submitted application lifetime is valid as per configured Queue lifetime.
checkAndGetApplicationPriority(Priority, UserGroupInformation, String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
checkAndGetApplicationPriority(Priority, UserGroupInformation, String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
checkAndGetApplicationPriority(Priority, UserGroupInformation, String, ApplicationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Verify whether a submitted application priority is valid as per configured Queue
checkAppNumCompletedLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
checkDecommissioningStatus(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher
 
checkForDeactivation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
checkForDecommissioningNodes(CheckForDecommissioningNodesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
checkForDecommissioningNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
It checks for any nodes in decommissioning state
checkIfStandbyRM() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
checkIfUsageOverFairShare(Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
checkIfUsageOverFairShare(Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
checkIfUsageOverFairShare(Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
checkIfUsageOverFairShare(Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Check if the resource usage is over the fair share under this policy.
checkMaxCapacity(String, float, float) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
 
checkQueueLabelExpression(Set<String>, String, RMContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Check queue label expression, check if node label in queue's node-label-expression existed in clusterNodeLabels if rmContext != null
checkReadyToBeDecommissioned(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher
 
checkRemoveFromClusterNodeLabelsOfQueue(Collection<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
checkSchedContainerChangeRequest(SchedContainerChangeRequest, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Validate increase/decrease request.
checkUserAccessToQueue(String, String, String, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method verifies if an user has access to a specified queue.
checkUserAccessToQueue(String, String, String, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
checkVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
checkVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
checkVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
1) Versioning scheme: major.minor.
checkVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
checkVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
 
childQueues - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
children - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivityNodeInfo
 
cleanName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
Replace the periods in the username or groupname with "_dot_" and remove trailing and leading whitespace.
CleanUpAppTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.CleanUpAppTransition
 
CleanUpContainerTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.CleanUpContainerTransition
 
cleanupExpiredQueues(String, boolean, Set<String>, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
First sets entitlement of queues to zero to prevent new app submission.
clearConfigurableFields() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
Clear configurable fields, like (absolute)capacity/(absolute)maximum-capacity, this will be used by queue reinitialize, when we reinitialize a queue, we will first clear all configurable fields, and load new values
clearNodeSetForAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
clearPendingContainerCache() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
clearPriorityACLs(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AppPriorityACLsManager
Clear priority acl during refresh.
clearQueueMetrics() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Helper method to clear cache.
ClientRMService - Class in org.apache.hadoop.yarn.server.resourcemanager
The client interface to the Resource Manager.
ClientRMService(RMContext, YarnScheduler, RMAppManager, ApplicationACLsManager, QueueACLsManager, RMDelegationTokenSecretManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
ClientRMService(RMContext, YarnScheduler, RMAppManager, ApplicationACLsManager, QueueACLsManager, RMDelegationTokenSecretManager, Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
ClientToAMTokenSecretManagerInRM - Class in org.apache.hadoop.yarn.server.resourcemanager.security
 
ClientToAMTokenSecretManagerInRM() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
clock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
cloneResourceRequest(ResourceRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
close() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
close() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
close() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Closes the configuration store, releasing any required resources.
close() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfigurationProvider
Closes the configuration provider, releasing any required resources.
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived classes close themselves using this method.
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
CLUSTER_RESOURCE_EMPTY - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
clusterId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
ClusterInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ClusterInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
ClusterInfo(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
ClusterMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ClusterMetrics() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
ClusterMetricsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ClusterMetricsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
ClusterMetricsInfo(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
ClusterMetricsInfo(ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
ClusterMonitor - Interface in org.apache.hadoop.yarn.server.resourcemanager
Implementations of this class are notified of changes to the cluster's state, such as node addition, removal and updates.
ClusterNodeTracker<N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Helper library that: - tracks the state of all cluster SchedulerNodes - provides convenience methods to filter and sort nodes
ClusterNodeTracker() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
clusterUsagePercentage - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
collect(ConstraintPlacementAlgorithmOutput) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithmOutputCollector
Collect an ConstraintPlacementAlgorithm output.
collectSchedulerApplications(Collection<ApplicationAttemptId>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Adds all applications in the queue and its subqueues to the given collection.
collectSchedulerApplications(Collection<ApplicationAttemptId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
collectSchedulerApplications(Collection<ApplicationAttemptId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
collectSchedulerApplications(Collection<ApplicationAttemptId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
collectSchedulerApplications(Collection<ApplicationAttemptId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
collectSchedulerApplications(Collection<ApplicationAttemptId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Adds all applications in the queue and its subqueues to the given collection.
CombinedSystemMetricsPublisher - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
A metrics publisher that can publish for a collection of publishers.
CombinedSystemMetricsPublisher(Collection<SystemMetricsPublisher>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
commitQueueManagementChanges(List<QueueManagementChange>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedQueueManagementPolicy
Commit/Update state for the specified queue management changes.
commitQueueManagementChanges(List<QueueManagementChange>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
Commit queue management changes - which involves updating required state on parent/underlying leaf queues
commonPreHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
comparator - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
compare(double, double, int, int) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.PriorityUtilizationQueueOrderingPolicy
Compare two queues with possibly different priority and assigned capacity, Will be used by preemption policy as well.
compare(NodeQueueLoadMonitor.ClusterNode, NodeQueueLoadMonitor.ClusterNode) - Method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor.LoadComparator
 
compare(FSAppAttempt, FSAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FifoAppComparator
 
compare(SchedulableEntity, SchedulableEntity) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy.FairComparator
 
compare(SchedulableEntity, SchedulableEntity) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoComparator
 
compare(SchedulableEntity, SchedulableEntity) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.PriorityComparator
 
compare(SchedulableEntity, SchedulableEntity) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.RecoveryComparator
 
compareAttribrutes(Schedulable, Schedulable) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
This method is used when apps are tied in fairness ratio.
compareInputOrderTo(SchedulableEntity) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.SchedulableEntity
Compare the passed SchedulableEntity to this one for input order.
compareInputOrderTo(SchedulableEntity) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
compareTo(ReservationAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
compareTo(ReservationInterval) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
 
compareTo(AllocationExpirationInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
compareTo(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
compareTo(AppPriorityACLGroup) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
compareTo(SchedContainerChangeRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
completed() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
completed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
COMPLETED_APPLICATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
completedAppsInStateStore - Variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
completedContainer(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
completedContainer(Resource, FiCaSchedulerApp, FiCaSchedulerNode, RMContainer, ContainerStatus, RMContainerEventType, CSQueue, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
A container assigned to the queue has completed.
completedContainer(Resource, FiCaSchedulerApp, FiCaSchedulerNode, RMContainer, ContainerStatus, RMContainerEventType, CSQueue, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
completedContainer(Resource, FiCaSchedulerApp, FiCaSchedulerNode, RMContainer, ContainerStatus, RMContainerEventType, CSQueue, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
completedContainerInternal(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
completedContainerInternal(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
completedContainerInternal(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Clean up a completed container.
completedContainerInternal(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
computeAbsoluteMaximumCapacity(float, CSQueue) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
 
computeAppsIdealAllocation(Resource, TempQueuePerPartition, Map<ApplicationAttemptId, Set<RMContainer>>, Resource, Resource, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
computeExecutionInterval(Plan, ReservationDefinition, ReservationRequest, boolean, RLESparseResourceAllocation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionInterval
Computes the earliest allowed starting time for a given stage.
computeExecutionInterval(Plan, ReservationDefinition, ReservationRequest, boolean, RLESparseResourceAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalByDemand
 
computeExecutionInterval(Plan, ReservationDefinition, ReservationRequest, boolean, RLESparseResourceAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalUnconstrained
 
ComputeFairShares - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies
Contains logic for computing the fair shares.
ComputeFairShares() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.ComputeFairShares
 
computeFixpointAllocation(Resource, Collection<TempQueuePerPartition>, Resource, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptableResourceCalculator
Given a set of queues compute the fix-point distribution of unassigned resources among them.
computeIdealAllocation(Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptableResourceCalculator
 
computeIdealResourceDistribution(ResourceCalculator, List<TempQueuePerPartition>, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptableResourceCalculator
This method computes (for a single level in the tree, passed as a List<TempQueue>) the ideal assignment of resources.
computeJobAllocation(Plan, ReservationId, ReservationDefinition, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
computeJobAllocation(Plan, ReservationId, ReservationDefinition, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
computeQueueManagementChanges() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedQueueManagementPolicy
Compute/Adjust child queue capacities for auto created leaf queues This computes queue entitlements but does not update LeafQueueState or queue capacities.
computeQueueManagementChanges() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
Compute/Adjust child queue capacities for auto created leaf queues This computes queue entitlements but does not update LeafQueueState or queue capacities.
computeShares(Collection<? extends Schedulable>, Resource, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.ComputeFairShares
Compute fair share of the given schedulables.Fair share is an allocation of shares considering only active schedulables ie schedulables which have running apps.
computeShares(Collection<? extends Schedulable>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
computeShares(Collection<? extends Schedulable>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
computeShares(Collection<? extends Schedulable>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
computeShares(Collection<? extends Schedulable>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Computes and updates the shares of Schedulables as per the SchedulingPolicy, to be used later for scheduling decisions.
computeStageAllocation(Plan, ReservationRequest, long, long, long, String, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
computeStageAllocation(Plan, RLESparseResourceAllocation, RLESparseResourceAllocation, ReservationRequest, long, long, long, String, ReservationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocator
Computes the allocation of a stage inside a defined time interval.
computeStageAllocation(Plan, RLESparseResourceAllocation, RLESparseResourceAllocation, ReservationRequest, long, long, long, String, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorGreedy
 
computeStageAllocation(Plan, RLESparseResourceAllocation, RLESparseResourceAllocation, ReservationRequest, long, long, long, String, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorGreedyRLE
 
computeStageAllocation(Plan, RLESparseResourceAllocation, RLESparseResourceAllocation, ReservationRequest, long, long, long, String, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
computeSteadyShares(Collection<? extends FSQueue>, Resource, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.ComputeFairShares
Compute the steady fair share of the given queues.
computeSteadyShares(Collection<? extends FSQueue>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
computeSteadyShares(Collection<? extends FSQueue>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
computeSteadyShares(Collection<? extends FSQueue>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
computeSteadyShares(Collection<? extends FSQueue>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Computes and updates the steady shares of FSQueues as per the SchedulingPolicy.
conf - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
conf - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
conf - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
conf - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppAttemptBlock
 
ConfigurableResource - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
A ConfigurableResource object represents an entity that is used to configure resources, such as maximum resources of a queue.
ConfigurableResource(double[]) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ConfigurableResource
 
ConfigurableResource(Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ConfigurableResource
 
configuration(CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig.Builder
 
ConfigurationMutationACLPolicy - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Interface for determining whether configuration mutations are allowed.
ConfigurationMutationACLPolicyFactory - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Factory class for creating instances of ConfigurationMutationACLPolicy.
configure(Map<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
configure(Map<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
configure(Map<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicy
 
configure(Map<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicyForPendingApps
 
configure(Map<String, String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Provides configuration information for the policy from the scheduler configuration.
configuredQueues(FSQueueType, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
confirmMutation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
confirmMutation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
confirmMutation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Should be called after logMutation.
confirmMutation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
confirmPendingMutation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
confirmPendingMutation(boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfigurationProvider
Confirm last logged mutation.
ConstraintPlacementAlgorithm - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
Marker interface for a Constraint Placement.
ConstraintPlacementAlgorithmInput - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
This encapsulates an input to the Constraint Placement Algorithm.
ConstraintPlacementAlgorithmOutput - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
Encapsulates the output of the ConstraintPlacementAlgorithm.
ConstraintPlacementAlgorithmOutput(ApplicationId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithmOutput
 
ConstraintPlacementAlgorithmOutputCollector - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
The ConstraintPlacementAlgorithm uses the ConstraintPlacementAlgorithmOutputCollector to collect any output it spits out.
constructZkRootNodeACL(Configuration, List<ACL>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
Given the Configuration and ACLs used (sourceACLs) for ZooKeeper access, construct the ACLs for the store's root node.
container() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
CONTAINER_RESERVED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
containerAllocated(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
containerAllocated(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
containerAllocated(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicy
 
containerAllocated(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicyForPendingApps
 
containerAllocated(S, RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Notify the OrderingPolicy that the SchedulableEntity has been allocated the given RMContainer, enabling the OrderingPolicy to take appropriate action.
ContainerAllocation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator
 
ContainerAllocation(RMContainer, Resource, AllocationState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
ContainerAllocationExpirer - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
ContainerAllocationExpirer(Dispatcher) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.ContainerAllocationExpirer
 
ContainerAllocationProposal<A extends SchedulerApplicationAttempt,N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
Proposal to allocate/reserve a new container
ContainerAllocationProposal(SchedulerContainer<A, N>, List<SchedulerContainer<A, N>>, SchedulerContainer<A, N>, NodeType, NodeType, SchedulingMode, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
ContainerAllocator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator
 
ContainerAllocator(FiCaSchedulerApp, ResourceCalculator, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocator
 
ContainerAllocator(FiCaSchedulerApp, ResourceCalculator, RMContext, ActivitiesManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocator
 
containerCompleted(RMContainer, ContainerStatus, RMContainerEventType, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
containerCreated(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
containerCreated(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
containerCreated(RMContainer, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
containerCreated(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
containerCreated(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
ContainerExpiredSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
The SchedulerEvent which notifies that a ContainerId has expired, sent by ContainerAllocationExpirer
ContainerExpiredSchedulerEvent(ContainerId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerExpiredSchedulerEvent
 
ContainerExpiredSchedulerEvent(ContainerId, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerExpiredSchedulerEvent
 
containerFinished(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
containerFinished(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.CombinedSystemMetricsPublisher
 
containerFinished(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
containerFinished(RMContainer, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.metrics.SystemMetricsPublisher
 
containerFinished(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
containerFinished(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
containerId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation.AssignmentDetails
 
containerId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
CONTAINERID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
containerIncreasedOnNode(ContainerId, SchedulerNode, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
ContainerLaunchContextInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class to allow users to send information required to create a ContainerLaunchContext which can then be used as part of the ApplicationSubmissionContext
ContainerLaunchContextInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
containerLaunchedOnNode(ContainerId, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
containerLaunchedOnNode(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
ContainerPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
ContainerPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.ContainerPage
 
ContainerPreemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
Simple event class used to communicate kill reserved containers, mark containers for preemption and kill already preemption-marked containers.
ContainerPreemptEvent(ApplicationAttemptId, RMContainer, SchedulerEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerPreemptEvent
 
containerReleased(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
containerReleased(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
containerReleased(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicy
 
containerReleased(S, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicyForPendingApps
 
containerReleased(S, RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Notify the OrderingPolicy that the SchedulableEntity has released the given RMContainer, enabling the OrderingPolicy to take appropriate action.
ContainerRequest - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
ContainerRequest is a class to capture resource requests associated with a Container, this will be used by scheduler to recover resource requests if the container preempted or cancelled before AM acquire the container.
ContainerRequest(List<ResourceRequest>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerRequest
 
ContainerRequest(SchedulingRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerRequest
 
CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
containersCPUUsage - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
containerStarted(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
containerStarted(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Inform the node that a container has launched.
ContainerUpdateContext - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Class encapsulates all outstanding container increase and decrease requests for an application.
ContainerUpdates - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Holder class that maintains list of container update requests
ContainerUpdates() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdates
 
contains(DeSelectFields.DeSelectType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields
Determine the deselect type should be handled or not.
containsGangs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
containsGangs() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns whether the reservation has gang semantics or not
containsNodeLabel(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AboutPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppAttemptPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppLogAggregationStatusPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ContainerPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeLabelsPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RedirectionErrorPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMErrorsAndWarningsPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
context - Variable in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
context - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptableResourceCalculator
 
context - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
CONTINUOUS_SCHEDULING_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
Continuous scheduling is known to cause locking issue inside the scheduler in larger cluster, more than 100 nodes, use FairSchedulerConfiguration.ASSIGN_MULTIPLE to improve container allocation ramp up.
CONTINUOUS_SCHEDULING_SLEEP_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
Continuous scheduling is known to cause locking issue inside Only used when FairSchedulerConfiguration.CONTINUOUS_SCHEDULING_ENABLED is enabled
continuousSchedulingEnabled - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
continuousSchedulingSleepMs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
ContractValidationException - Exception in org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions
This exception is thrown if the request made is not syntactically valid.
ContractValidationException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.ContractValidationException
 
convertAllocationsToReservationInfo(Set<ReservationAllocation>, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
convertFromProtoFormat(YarnServerResourceManagerRecoveryProtos.RMAppAttemptStateProto) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
convertFromProtoFormat(YarnServerResourceManagerRecoveryProtos.RMAppStateProto) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
convertFromProtoFormat(YarnProtos.ReservationDefinitionProto) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
convertFromProtoFormat(YarnProtos.ReservationIdProto) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
convertToNodeUpdateType(RMAppNodeUpdateEvent.RMAppNodeUpdateType) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent.RMAppNodeUpdateType
 
convertToProtoFormat(RMAppAttemptState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
convertToProtoFormat(RMAppState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
convertToProtoFormat(Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
convertToStringSet(Set<NodeLabel>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.NodeLabelsUtils
 
copyAllUsed(AbstractResourceUsage) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
COULD_NOT_GET_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
count - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
create() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
create - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
 
create() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
CREATE_NEW_RESERVATION_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
createAbnormalContainerStatus(ContainerId, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility to create a ContainerStatus during exceptional circumstances.
createAdminService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createAllocationTags(ApplicationId, String, Set<String>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
createAllocationTagsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createAMLauncher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createAMLivelinessMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createAMRMTokenSecretManager(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
createAndGetAMRMToken(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
createAndGetApplicationReport(String, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
To get the status of an application in the RM, this method can be used.
createAndGetApplicationReport(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
createAndGetNMToken(String, ApplicationAttemptId, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
createAndInitActiveServices(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Helper method to create and init ResourceManager.activeServices.
createAndInitializeRule(Node) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementPolicy
Create and initialize a rule given a xml node
createAndSetAMRMToken() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
createAndStartZKManager(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Get ZooKeeper Curator manager, creating and starting if not exists.
createApplicationAttemptReport() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Create the Application attempt report from the RMAppAttempt
createApplicationAttemptReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
createApplicationAttemptState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Create the external user-facing state of the attempt of ApplicationMaster from the current state of the RMAppAttempt.
createApplicationAttemptState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
createApplicationAttemptState(RMAppAttemptState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
createApplicationHistoryStore(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
createApplicationMasterService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createApplicationMetricsTable(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
createApplicationState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Create the external user-facing state of ApplicationMaster from the current state of the RMApp.
createApplicationState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
createApplicationState(RMAppState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
createAppSubmissionContext(ApplicationSubmissionContextInfo, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebAppUtil
Create the actual ApplicationSubmissionContext to be submitted to the RM from the information provided by the user.
createAttemptHeadRoomTable(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppAttemptBlock
 
createClientRMService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createClientToAMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
createClientToken(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Create a token for authenticating a client connection to the app attempt
createClientToken(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
createContainerQueuingLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.QueueLimitCalculator
 
createContainerReport() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
createContainerReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
createContainerToken(ContainerId, int, NodeId, String, Resource, Priority, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
 
createContainerToken(ContainerId, int, NodeId, String, Resource, Priority, long, LogAggregationContext, String, ContainerType, ExecutionType, long, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
Helper function for creating ContainerTokens.
createContainerTokenSecretManager(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
createDefaultReservationQueue(String, Queue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Creates the default reservation queue for use when no reservation is used for applications submitted to this planQueue.
createDefaultReservationQueue(String, Queue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
createDefaultReservationQueue(String, Queue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
createDelegationTokenRenewer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createDispatcher(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
createDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter.MultiThreadedDispatcher
 
createDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.MultiThreadedDispatcher
 
createDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createEmbeddedElector() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createGlobalAllocationTags(Set<String>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
createIdentifier() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Creates an empty TokenId to be used for de-serializing an AMRMTokenIdentifier by the RPC layer.
createIdentifier() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
createKilledContainerStatus(ContainerId, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility to create a ContainerStatus for killed containers.
createMasterKey(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
createNewApplication(HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Generates a new ApplicationId which is then sent to the client.
createNewApplication(HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
createNewMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
createNewReservation(HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Generates a new ReservationId which is then sent to the client.
createNewReservation(HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
createNewThreadPoolService(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
createNMTokenSecretManager(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
createNodeLabelManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createOpportunisticRmContainer(RMContext, Container, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
createOtherAppAllocationTags(ApplicationId, Set<String>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
createPassword(AMRMTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
createPlacementConstraintManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createPreemptedContainerStatus(ContainerId, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility to create a ContainerStatus during exceptional circumstances.
createPreemptionThread() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
createQueueACLsManager(ResourceScheduler, Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createReleaseCache() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
createReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
createReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.GreedyReservationAgent
 
createReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
createReservation(ReservationId, String, Plan, ReservationDefinition) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.ReservationAgent
Create a reservation for the user that abides by the specified contract
createReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.TryManyReservationAgents
 
createReservationSystem() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createResourceCommitRequest(CSAssignment) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
createResourceProfileManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createResourceTrackerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRMApplicationHistoryWriter() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRMAppLifetimeMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRMAppManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRMDelegatedNodeLabelsUpdater() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Create RMDelegatedNodeLabelsUpdater based on configuration.
createRMDelegationTokenSecretManager(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
createRMSecretManagerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRunnableLauncher(RMAppAttempt, AMLauncherEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
createSchedContainerChangeRequests(List<UpdateContainerRequest>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
createScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createSchedulerEventDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createServiceManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createSingleAppAllocationTags(ApplicationId, Set<String>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
createSystemMetricsPublisher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createTablesForAttemptMetrics(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppAttemptBlock
 
createTreeNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AllocationActivity
 
createUnknownNodeId(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
A NodeId instance needed upon startup for populating inactive nodes Map.
CredentialsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
CredentialsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CredentialsInfo
 
CSAMContainerLaunchDiagnosticsConstants - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
diagnostic messages for AMcontainer launching
CSAssignment - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
CSAssignment(Resource, NodeType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
CSAssignment(FiCaSchedulerApp, RMContainer) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
CSAssignment(CSAssignment.SkippedType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
CSAssignment(Resource, NodeType, RMContainer, FiCaSchedulerApp, CSAssignment.SkippedType, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
CSAssignment.SkippedType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Reason for the queue to get skipped.
CSConfigurationProvider - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
Configuration provider for CapacityScheduler.
csContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
CSQueue - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
CSQueue represents a node in the tree of hierarchical queues in the CapacityScheduler.
CSQueueMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
CSQueueUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
CSQueueUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
 
cumulativeCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
CuratorBasedElectorService - Class in org.apache.hadoop.yarn.server.resourcemanager
Leader election implementation that uses Curator.
CuratorBasedElectorService(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
current - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
CURRENT_USER_MAPPING - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule
 
CURRENT_VERSION_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
CURRENT_VERSION_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
CURRENT_VERSION_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
CURRENT_VERSION_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 

D

deactivateApp(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
deactivateApplication(String, ApplicationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractUsersManager
An application has no more outstanding requests.
deactivateApplication(String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
An application has no more outstanding requests.
deactivateApplication(String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
deactivateNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
deactivateNode(RMNodeImpl, NodeState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
Put a node in deactivated (decommissioned or shutdown) status.
DeactivateNodeTransition(NodeState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.DeactivateNodeTransition
 
decAMLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decAMLimit(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decAMUsed(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
decAMUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decAMUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decAMUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
DecommissioningNodesWatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
DecommissioningNodesWatcher is used by ResourceTrackerService to track DECOMMISSIONING nodes to decide when, after all running containers on the node have completed, will be transitioned into DECOMMISSIONED state (NodeManager will be told to shutdown).
DecommissioningNodesWatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher
 
DecommissioningNodesWatcher.DecommissioningNodeStatus - Enum in org.apache.hadoop.yarn.server.resourcemanager
Status about a specific decommissioning node.
DecommissioningNodeTransition(NodeState, NodeState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.DecommissioningNodeTransition
 
decPending(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decPending(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decPendingResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
decPendingResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
decPendingResource(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
When an outstanding resource is fulfilled or canceled, calling this will decrease pending resource in a queue.
decPendingResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
decPendingResource(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
When an outstanding resource is fulfilled or canceled, calling this will decrease pending resource in a queue.
decrActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
decrDecommisionedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrDecommissioningNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decReserved(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decReserved(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decReservedResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
decReservedResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
decReservedResource(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Decrement Reserved Capacity
decrNumActiveNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrNumLostNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrNumRebootedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrNumShutdownNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrNumUnhealthyNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrPendingResources(String, String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
decUnconfirmedRes(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
decUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
decUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
decUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
When partition of node updated, we will update queue's resource usage if it has container(s) running on that.
decUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
decUsedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Decrease resource usage for this queue and all parent queues.
deductActuallyToBePreempted(ResourceCalculator, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
deductActuallyToBePreempted(ResourceCalculator, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
deductPreemptableResourcesBasedSelectedCandidates(CapacitySchedulerPreemptionContext, Map<ApplicationAttemptId, Set<RMContainer>>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionUtils
 
deductUnallocatedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Deduct unallocated resources from the node.
Default() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Default
 
DEFAULT_ADDITIONAL_RESOURCE_BALANCE_BASED_ON_RESERVED_CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_ALLOCATION_FILE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_ALLOW_UNDECLARED_POOLS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_APP_FAIL_FAST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_APP_ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_APPLICATION_PLACEMENT_TYPE_CLASS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ApplicationSchedulingConfig
 
DEFAULT_APPLICATION_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_ASSIGN_MULTIPLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_ASSIGN_MULTIPLE_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_AUTO_CREATE_CHILD_QUEUE_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_AUTO_CREATE_QUEUE_MAX_QUEUES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_AUTO_CREATED_QUEUE_MANAGEMENT_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_CAPACITY_OVER_TIME_MULTIPLIER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_CONFIGURATION_APPLICATION_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_CONTINUOUS_SCHEDULING_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
DEFAULT_CONTINUOUS_SCHEDULING_SLEEP_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
DEFAULT_ENABLE_QUEUE_MAPPING_OVERRIDE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_ENABLE_USER_METRICS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_END_TIME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
DEFAULT_FAIL_AUTO_CREATION_ON_EXCEEDING_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_GREEDY_FAVOR_EARLY_ALLOCATION - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.ReservationAgent
By default favor early allocations.
DEFAULT_INCLUDE_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
DEFAULT_INTRAQUEUE_PREEMPTION_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_INTRAQUEUE_PREEMPTION_MAX_ALLOWABLE_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_INTRAQUEUE_PREEMPTION_MINIMUM_THRESHOLD - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_INTRAQUEUE_PREEMPTION_ORDER_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_LAZY_PREEMPTION_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_LIFETIME_SUFFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_LOCALITY_DELAY_NODE_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
DEFAULT_LOCALITY_DELAY_RACK_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
DEFAULT_LOCALITY_THRESHOLD - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_LOCALITY_THRESHOLD_NODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_LOCALITY_THRESHOLD_RACK - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_MAX_ASSIGN - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_MAX_ASSIGN_PER_HEARTBEAT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_MAX_WAIT_BEFORE_KILL_FOR_QUEUE_BALANCE_PREEMPTION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_MAXIMUM_APPLICATIONMASTERS_RESOURCE_PERCENT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_MAXIMUM_CAPACITY_VALUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_MAXIMUM_SYSTEM_APPLICATIIONS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_NODE_LABEL_EXPRESSION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_NODE_LOCALITY_DELAY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_OFFSWITCH_PER_HEARTBEAT_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
DEFAULT_PREEMPTION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_PREEMPTION_MAX_IGNORED_OVER_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION_MONITORING_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION_NATURAL_TERMINATION_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION_OBSERVE_ONLY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION_SELECT_CANDIDATES_FOR_RESERVED_CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION_THRESHOLD - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_PREEMPTION_TO_BALANCE_QUEUES_BEYOND_GUARANTEED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION_WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PROFILE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
DEFAULT_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
DEFAULT_QUEUE_MANAGEMENT_MONITORING_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_QUEUE_ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_QUEUE_SUFFIX - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationConstants
The suffix used for a queue under a reservable queue that will be used as a default queue whenever no reservation is used
DEFAULT_RACK_LOCALITY_ADDITIONAL_DELAY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_RACK_LOCALITY_FULL_RESET - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_RESERVATION_ADMISSION_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_RESERVATION_AGENT_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_RESERVATION_ENFORCEMENT_WINDOW - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_RESERVATION_ID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
DEFAULT_RESERVATION_MOVE_ON_EXPIRY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_RESERVATION_PLANNER_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_RESERVATION_WINDOW - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_RESERVE_CONT_LOOK_ALL_NODES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_RESOURCE_CALCULATOR_CLASS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_RESOURCE_TYPES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_RM_SCHEDULER_INCREMENT_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
DEFAULT_RM_SCHEDULER_INCREMENT_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
DEFAULT_RM_SCHEDULER_RESERVATION_THRESHOLD_INCREMENT_MULTIPLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_RM_SYSTEM_CREDENTIALS_VALID_TIME_REMAINING - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
DEFAULT_SCHEDULE_ASYNCHRONOUSLY_ENABLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_SCHEDULE_ASYNCHRONOUSLY_MAXIMUM_PENDING_BACKLOGS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_SHOW_RESERVATIONS_AS_QUEUES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
DEFAULT_SIZE_BASED_WEIGHT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_SMOOTHNESS_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
DEFAULT_START_TIME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
DEFAULT_TOTAL_PREEMPTION_PER_ROUND - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_UPDATE_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_USER_AS_DEFAULT_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_USER_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_USER_LIMIT_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_USER_WEIGHT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_WAIT_TIME_BEFORE_NEXT_STARVATION_CHECK_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DefaultConfigurationMutationACLPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Default configuration mutation ACL policy.
DefaultConfigurationMutationACLPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.DefaultConfigurationMutationACLPolicy
 
defaultNodeLabelExpression - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
DefaultPlacementAlgorithm - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm
Basic placement algorithm.
DefaultPlacementAlgorithm() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.DefaultPlacementAlgorithm
 
defaultPriority - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
DELEGATION_KEY_PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
DELEGATION_TOKEN - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#postDelegationToken and RMWebServiceProtocol#cancelDelegationToken.
DELEGATION_TOKEN_EXPIRATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#postDelegationTokenExpiration.
DELEGATION_TOKEN_HEADER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
DELEGATION_TOKEN_PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
DELEGATION_TOKEN_SEQUENCE_NUMBER_PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
DelegationToken - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
DelegationToken() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
DelegationToken(String, String, String, String, Long, Long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
delegationTokenNodeSplitIndex - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
DelegationTokenRenewer - Class in org.apache.hadoop.yarn.server.resourcemanager.security
Service to renew application delegation tokens.
DelegationTokenRenewer() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
DelegationTokenRenewer.DelegationTokenToRenew - Class in org.apache.hadoop.yarn.server.resourcemanager.security
class that is used for keeping tracks of DT to renew
DelegationTokenToRenew(Collection<ApplicationId>, Token<?>, Configuration, long, boolean, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
DELETE_RESERVATION_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
deleteApplicationHomeSubCluster(DeleteApplicationHomeSubClusterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
deleteReservation(ReservationDeleteRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
deleteReservation(ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
deleteReservation(ReservationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanEdit
Delete an existing ReservationAllocation from the plan identified uniquely by its ReservationId.
deleteReservation(ReservationId, String, Plan) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
deleteReservation(ReservationId, String, Plan) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.GreedyReservationAgent
 
deleteReservation(ReservationId, String, Plan) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
deleteReservation(ReservationId, String, Plan) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.ReservationAgent
Delete an user reservation
deleteReservation(ReservationId, String, Plan) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.TryManyReservationAgents
 
deleteReservation(ReservationDeleteRequestInfo, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Function to delete a Reservation to the RM.
deleteReservation(ReservationDeleteRequestInfo, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
deleteStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
deleteStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
deleteStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
deleteStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
deleteStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived classes must implement this method to delete the state store
deleteStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
DELIMITER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
demandUpdated(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
demandUpdated(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
demandUpdated(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicy
 
demandUpdated(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicyForPendingApps
 
demandUpdated(S) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Notify the OrderingPolicy that the demand for the SchedulableEntity has been updated, enabling the OrderingPolicy to reorder the SchedulableEntity if needed.
deregisterSubCluster(SubClusterDeregisterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
DeSelectFields - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
DeSelectFields make the /apps api more flexible.
DeSelectFields() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields
 
DeSelectFields.DeSelectType - Enum in org.apache.hadoop.yarn.server.resourcemanager.webapp
Deselect field type, can be boost in future.
DESELECTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
destroy() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
detachContainer(Resource, FiCaSchedulerApp, RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Detach a container from this queue
detachContainer(Resource, FiCaSchedulerApp, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
detachContainer(Resource, FiCaSchedulerApp, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
DetailedInformation(long, NodeId, ContainerId, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth.DetailedInformation
 
diagnostic - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
diagnostic - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivityNodeInfo
 
diagnostic - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
diagnostic - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
diagnostics - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
diagnostics - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
DirectResolver() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.DirectResolver
 
DISABLE_DELEGATED_NODE_LABELS_UPDATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
 
DisabledBlacklistManager - Class in org.apache.hadoop.yarn.server.resourcemanager.blacklist
A BlacklistManager that returns no blacklists.
DisabledBlacklistManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.blacklist.DisabledBlacklistManager
 
DisabledPlacementProcessor - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
Processor that reject all SchedulingRequests.
DisabledPlacementProcessor() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.DisabledPlacementProcessor
 
DO_NOT_NEED_ALLOCATIONATTEMPTINFOS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
doFilter(HttpServletRequest, HttpServletResponse, FilterChain) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebAppFilter
 
DominantResourceFairnessComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
 
DominantResourceFairnessPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies
Makes scheduling decisions by trying to equalize dominant resource usage.
DominantResourceFairnessPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
DominantResourceFairnessPolicy.DominantResourceFairnessComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies
This class compares two Schedulable instances according to the DRF policy.
doPostPut(ApplicationId, TimelineCollector) - Method in class org.apache.hadoop.yarn.server.resourcemanager.timelineservice.RMTimelineCollectorManager
 
doSecureLogin() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
DOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
DOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DUMMY_APPLICATION_RESOURCE_USAGE_REPORT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Statically defined dummy ApplicationResourceUsageREport.
dumpSchedulerLogs(String, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method dumps the scheduler logs for the time got in input, and it is reachable by using RMWSConsts.SCHEDULER_LOGS.
dumpSchedulerLogs(String, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
dumpState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Recursively dump states of all queues.
dumpStateInternal(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
dumpStateInternal(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
dumpStateInternal(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Recursively dump states of all queues.
DurationInterval(long, long, double, int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
DYNAMIC_MAX_ASSIGN - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Maximum number of containers to assign on each check-in.
DynamicResourceConfiguration - Class in org.apache.hadoop.yarn.server.resourcemanager.resource
 
DynamicResourceConfiguration() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
DynamicResourceConfiguration(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
DynamicResourceConfiguration(Configuration, InputStream) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 

E

editSchedule() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
editSchedule() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.MetricsInvariantChecker
 
editSchedule() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.ReservationInvariantsChecker
 
editSchedule() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
This method is invoked at regular intervals.
editSchedule() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
elapsedTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
EmbeddedElector - Interface in org.apache.hadoop.yarn.server.resourcemanager
Interface that all embedded leader electors must implement.
EMPTY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
EMPTY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
EMPTY_ALLOCATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
EMPTY_ALLOCATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
ENABLE_QUEUE_MAPPING_OVERRIDE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
ENABLE_SIZE_BASED_WEIGHT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
ENABLE_USER_METRICS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
END_TIME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
enterNeutralMode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
When the ZK client loses contact with ZK, this method will be called to allow the RM to react.
entitiesToReorder - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
entityRequiresReordering(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
ENV_APPLICATION_PLACEMENT_TYPE_CLASS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ApplicationSchedulingConfig
 
Epoch - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
The epoch information of RM for work-preserving restart.
Epoch() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
EPOCH_BIT_SHIFT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Used for generation of various ids.
EPOCH_NODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
EpochPBImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb
 
EpochPBImpl() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.EpochPBImpl
 
EpochPBImpl(YarnServerResourceManagerRecoveryProtos.EpochProto) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.EpochPBImpl
 
EPSILON - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.TimelinePublishEvent
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppToMonitor
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
ErrorBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
This class is used to display an error message to the user in the UI.
errorsAndWarnings() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
Evaluable<T> - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
A class implements Evaluable interface represents the internal state of the class can be changed against a given target.
evaluate(T) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.Evaluable
Evaluate against a given target, this process changes the internal state of current class.
evaluate(TargetApplications) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.AppTag
 
evaluate(TargetApplications) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
Evaluate the namespace against given target applications if it is necessary.
evaluate(TargetApplications) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.NotSelf
 
evaluate(TargetApplications) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.Self
 
EVERYBODY_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileQueueParser
 
exceedQueueMaxRunningApps(FSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Recursively checks whether the number of queue runnable apps exceeds the limitation.
exceedUserMaxApps(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Checks whether the number of user runnable apps exceeds the limitation.
ExecutionTypeRequestInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class representing an execution type request.
ExecutionTypeRequestInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ExecutionTypeRequestInfo
 
ExecutionTypeRequestInfo(ExecutionTypeRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ExecutionTypeRequestInfo
 
exists(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
exists(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Return whether a queue exists already.
expirationDate - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
expire(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NMLivelinessMonitor
 
expire(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AMLivelinessMonitor
 
expire(RMAppToMonitor) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
expire(AllocationExpirationInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.ContainerAllocationExpirer
 
EXPIRED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 

F

FAIL_ATTEMPT_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
FAIL_AUTO_CREATION_ON_EXCEEDING_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
FAIL_TO_ALLOCATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
failApplicationAttempt(FailApplicationAttemptRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
failure() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
FAIR_APP_ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
FairComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy.FairComparator
 
FairOrderingPolicy<S extends SchedulableEntity> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
An OrderingPolicy which orders SchedulableEntities for fairness (see FairScheduler FairSharePolicy), generally, processes with lesser usage are lesser.
FairOrderingPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
FairOrderingPolicy.FairComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
 
FairReservationSystem - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
 
FairReservationSystem() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
FairScheduler - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
A scheduler that schedules resources between a set of queues.
FairScheduler() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
FairSchedulerAppsBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
Shows application information specific to the fair scheduler as part of the fair scheduler page.
FairSchedulerAppsBlock(ResourceManager, View.ViewContext, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerAppsBlock
 
FairSchedulerConfiguration - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FairSchedulerConfiguration() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
FairSchedulerConfiguration(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
FairSchedulerInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
FairSchedulerInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
 
FairSchedulerInfo(FairScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
 
FairSchedulerLeafQueueInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
FairSchedulerLeafQueueInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerLeafQueueInfo
 
FairSchedulerLeafQueueInfo(FSLeafQueue, FairScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerLeafQueueInfo
 
FairSchedulerPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
FairSchedulerPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
FairSchedulerPlanFollower - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
 
FairSchedulerPlanFollower() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
FairSchedulerQueueInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
FairSchedulerQueueInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
FairSchedulerQueueInfo(FSQueue, FairScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
FairSchedulerQueueInfoList - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
FairScheduler QueueInfo list used for mapping to XML or JSON.
FairSchedulerQueueInfoList() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfoList
 
FairSchedulerUtilities - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Utility class for the Fair Scheduler.
FairSharePolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies
Makes scheduling decisions by trying to equalize shares of memory.
FairSharePolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
fairSharePreemptionThresholds(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
fairSharePreemptionTimeouts(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
FAVOR_EARLY_ALLOCATION - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.ReservationAgent
Constant defining the preferential treatment of time for equally valid allocations.
FederationStateStoreHeartbeat - Class in org.apache.hadoop.yarn.server.resourcemanager.federation
Periodic heart beat from a ResourceManager participating in federation to indicate liveliness.
FederationStateStoreHeartbeat(SubClusterId, FederationStateStore, ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreHeartbeat
 
FederationStateStoreService - Class in org.apache.hadoop.yarn.server.resourcemanager.federation
Implements FederationStateStore and provides a service for participating in the federation membership.
FederationStateStoreService(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
fenceOldActive(byte[]) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
FiCaSchedulerApp - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica
Represents an application attempt from the viewpoint of the FIFO or Capacity scheduler.
FiCaSchedulerApp(ApplicationAttemptId, String, Queue, AbstractUsersManager, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
FiCaSchedulerApp(ApplicationAttemptId, String, Queue, AbstractUsersManager, RMContext, Priority, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
FiCaSchedulerApp(ApplicationAttemptId, String, Queue, AbstractUsersManager, RMContext, Priority, boolean, ActivitiesManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
FiCaSchedulerNode - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica
 
FiCaSchedulerNode(RMNode, boolean, Set<String>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
FiCaSchedulerNode(RMNode, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
FIFO_APP_ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
FifoAppAttempt - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo
 
FifoAppComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Order FSAppAttempt objects by priority and then by submit time, as in the default scheduler in Hadoop.
FifoAppComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FifoAppComparator
 
FifoCandidatesSelector - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
 
FifoComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
A Comparator which orders SchedulableEntities by input order
FifoComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoComparator
 
FifoIntraQueuePreemptionPlugin - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
FifoIntraQueuePreemptionPlugin will handle intra-queue preemption for priority and user-limit.
FifoIntraQueuePreemptionPlugin(ResourceCalculator, CapacitySchedulerPreemptionContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
FifoOrderingPolicy<S extends SchedulableEntity> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
An OrderingPolicy which orders SchedulableEntities by input order
FifoOrderingPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicy
 
FifoOrderingPolicyForPendingApps<S extends SchedulableEntity> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
This ordering policy is used for pending applications only.
FifoOrderingPolicyForPendingApps() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicyForPendingApps
 
FifoPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies
 
FifoPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
FifoScheduler - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo
 
FifoScheduler() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
FifoSchedulerInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
FifoSchedulerInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
FifoSchedulerInfo(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
FileBasedCSConfigurationProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
CapacityScheduler configuration provider based on local capacity-scheduler.xml file.
FileBasedCSConfigurationProvider(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.FileBasedCSConfigurationProvider
Construct file based CS configuration provider with given context.
FileSystemRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
FileSystemRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
filterByMaxDeductAssigned(ResourceCalculator, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
This method is visible to allow sub-classes to override the behavior, specifically for federation purposes we do not want to cap resources as it is done here.
FINAL_STATUS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
finalAllocationState - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeAllocationInfo
 
finalStatus - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
findEarliestTime(Map<ReservationInterval, Resource>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
findLatestTime(Map<ReservationInterval, Resource>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
findNodeToUnreserve(FiCaSchedulerNode, SchedulerRequestKey, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
FINISH_FAILED_APP - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
FINISH_KILLED_APP - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
FINISH_SUCCESS_APP - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
finishAllocatedAppAllocationRecording(ActivitiesManager, ApplicationId, ContainerId, ActivityState, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
finishAllocatedNodeAllocation(ActivitiesManager, SchedulerNode, ContainerId, AllocationState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.NODE
 
finishApp(String, RMAppState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
finishAppAttempt(ApplicationId, boolean, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
finishApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
finishApplication(ApplicationId, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
An application submitted to this queue has finished.
finishApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
finishApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
finishApplication(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
finishApplicationAttempt(FiCaSchedulerApp, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
An application attempt submitted to this queue has finished.
finishApplicationAttempt(FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
finishApplicationAttempt(FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
finishApplicationMaster(FinishApplicationMasterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
finishApplicationMaster(ApplicationAttemptId, FinishApplicationMasterRequest, FinishApplicationMasterResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.AbstractPlacementProcessor
 
finishApplicationMaster(ApplicationAttemptId, FinishApplicationMasterRequest, FinishApplicationMasterResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.PlacementConstraintProcessor
 
FINISHED_TIME_BEGIN - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
FINISHED_TIME_END - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
finishedTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
finishedTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
finishNodeUpdateRecording(ActivitiesManager, NodeId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.NODE
 
finishSkippedAppAllocationRecording(ActivitiesManager, ApplicationId, ActivityState, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
finishSkippedNodeAllocation(ActivitiesManager, SchedulerNode) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.NODE
 
forceKillApplication(KillApplicationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
forQueue(String, Queue, boolean, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
forQueue(String, Queue, boolean, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
forQueue(MetricsSystem, String, Queue, boolean, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Get the FS queue metric for the given queue.
forQueue(String, Queue, boolean, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
forQueue(MetricsSystem, String, Queue, boolean, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
FORWARDED_FOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
fromConfiguration(Configuration, Map<FSQueueType, Set<String>>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementPolicy
Build a simple queue placement policy from the allow-undeclared-pools and user-as-default-queue configuration options.
fromSchedulerNode(FiCaSchedulerNode) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
fromXml(Element, Map<FSQueueType, Set<String>>, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementPolicy
Builds a QueuePlacementPolicy from an xml element.
fs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
FSAppAttempt - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Represents an application attempt from the viewpoint of the Fair Scheduler.
FSAppAttempt(FairScheduler, ApplicationAttemptId, String, FSLeafQueue, ActiveUsersManager, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
fsConf - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
FSContext - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Helper class that holds basic information to be passed around FairScheduler classes.
fsContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
 
FSLeafQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSLeafQueue(String, FairScheduler, FSParentQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
FSOpDurations - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Class to capture the performance metrics of FairScheduler.
FSParentQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSParentQueue(String, FairScheduler, FSParentQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
FSQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSQueue(String, FairScheduler, FSParentQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
FSQueueMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSQueueType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSSchedulerNode - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Fair Scheduler specific node features.
FSSchedulerNode(RMNode, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 

G

generateApplicationTable(HtmlBlock.Block, UserGroupInformation, Collection<ApplicationAttemptReport>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
generateOverview(ApplicationAttemptReport, Collection<ContainerReport>, AppAttemptInfo, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppAttemptBlock
 
get(CapacitySchedulerContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule
 
get() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the cluster information, and it is reachable by using RMWSConsts.INFO.
get() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
GET_APP_ATTEMPT_REPORT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_APP_ATTEMPTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_APP_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_APP_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_APP_STATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_APP_TIMEOUTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_APPLICATIONS_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RouterWebServices#getContainer.
GET_CONTAINER_REPORT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
GET_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
GET_NODE_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getClusterNodeLabels.
GET_NODE_TO_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getNodeToLabels.
GET_QUEUE_INFO_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
getAbsoluteActivatedChildQueueCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
getAbsoluteCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getAbsoluteCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get capacity of the parent of the queue as a function of the cumulative capacity in the cluster.
getAbsoluteCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getAbsoluteCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getAbsoluteMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getAbsoluteMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getAbsoluteMaximumCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getAbsoluteMaximumCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get maximum-capacity of the queue as a funciton of the cumulative capacity of the cluster.
getAbsoluteMaximumCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteMaximumCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteReservedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteReservedCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getAbsoluteUsedCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the current absolute used capacity of the queue relative to the entire cluster.
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteUsedCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getAbstractUsersManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the AbstractUsersManager for the queue.
getAbstractUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getAbstractUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getAbstractUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getAbstractUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
getAbstractUsersManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
 
getAcceptanceTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getAcceptanceTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the time at which the reservation was accepted by the system
getAcceptanceTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
getAccessControlList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
getAccessibleNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getAccessibleNodeLabels(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getAccessibleNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getAccessibleNodeLabels() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get labels can be accessed of this queue labels={*}, means this queue can access any label labels={ }, means this queue cannot access any label except node without label labels={a, b, c} means this queue can access a or b or c
getAcl(String, QueueACL) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getACLList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
getAclMutationPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
getAclMutationPolicy() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfigurationProvider
Get the acl mutation policy for this configuration provider.
getACLs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getAcls(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getAcls() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
getActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getActiveApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getActivedAppDiagnosticMessage(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getActivedAppDiagnosticMessage(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getActiveNMCountPerLabel(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
getActiveNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getActiveServiceContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
RM Active service context.
getActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getActivities(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieve all the activities in a specific node, and it is reachable by using RMWSConsts.SCHEDULER_ACTIVITIES.
getActivities(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getActivitiesInfo(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
getActivitiesManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getActivitiesManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getActuallyToBePreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getAddedRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeAddedSchedulerEvent
 
getAdmissionPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getAgent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getAggegatedReleasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAggregateAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAggregateAllocationCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getAggregateAppResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getAggregatedContainersPhysicalMemoryMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
getAggregatedContainersUtilization() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the aggregated resource utilization of the containers.
getAggregatedContainersUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getAggregatedContainersUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getAggregatedContainersUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the resource utilization of the containers in the node.
getAggregatedContainersVirtualMemoryMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
getAggregateFulFilledReservationsCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getAggregateNodeLocalContainersAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAggregateOffSwitchContainersAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAggregatePreemptedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAggregatePreemptionCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getAggregateRackLocalContainersAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAggregateReleaseCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getAggregateReservationCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getAllApplicationIds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplications
 
getAllApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Obtain (read-only) collection of all applications.
getAllApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
getAllMasterKeys() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getAllNodeIds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
getAllNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getAllNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
getAllNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.CandidateNodeSet
Get all nodes for this CandidateNodeSet
getAllNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SimpleCandidateNodeSet
 
getAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getAllocatedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAllocatedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAllocatedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAllocatedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAllocatedNode() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getAllocatedNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getAllocatedOrReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getAllocatedOrReservedResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getAllocatedOrReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getAllocatedOrReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getAllocatedPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getAllocatedPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getAllocatedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getAllocatedResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getAllocatedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getAllocatedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get allocated resources on the node.
getAllocatedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAllocatedSchedulerKey() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getAllocatedSchedulerKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getAllocatedVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAllocatedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAllocatedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAllocatedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAllocateFromReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getAllocateResponse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService.AllocateResponseLock
 
getAllocation(ResourceCalculator, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
This method produces an Allocation that includes the current view of the resources that will be allocated to and preempted from this application.
getAllocationAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getAllocationConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getAllocationCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getAllocationDetails() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getAllocationFile(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
Path to XML file containing allocations.
getAllocationLocalityType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getAllocationRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getAllocationRequests() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the map of resources requested against the time interval for which they were.
getAllocationsCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagInfo
 
getAllocationState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
getAllocationTag() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagInfo
 
getAllocationTags() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
Return SchedulingRequest.getAllocationTags() specified by AM.
getAllocationTags() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getAllocationTagsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getAllocationTagsManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAllocationTagsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getAllocationTagsSummary() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getAllocationTagsWithCount() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
Get the allocation tags and their counts associated with this node.
getAllocationTagsWithCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getAllocationTagsWithCount(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Returns a map whose key is the allocation tag and value is the count of allocations with this tag.
getAllowQueuesBalanceAfterAllQueuesSatisfied() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoCandidatesSelector
 
getAllPartitions() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getAllPartitions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getAllPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getAllPlans() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getAllPlans() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Return a map containing all the plans known to this ReservationSystem (useful for UI)
getAllReservations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getAllResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
Used by REST API to fetch ResourceRequest
getAllTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
getAllTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getAllUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getAllUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getAllUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Get all valid users in this queue.
getAllUserWeightsForQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get the weights of all users at this queue level from the configuration.
getAMBlacklistManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Get the BlacklistManager that manages blacklists for AM failures
getAMBlacklistManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getAMContainerExitStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
getAMContainerExitStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getAMContainerExitStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getAMContainerLogs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAMContainerNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getAMFinishingMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getAMFinishingMonitor() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAMFinishingMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getAMHostHttpAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAMLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getAMLimit(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getAMLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getAMLivelinessMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getAMLivelinessMonitor() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAMLivelinessMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getAMMaxResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getAmNodeLabelExpression() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Return the node label expression of the AM container.
getAmNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getAmNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAmountNeededUnreserve() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
getAMResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getAMResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getAMResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getAMResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getAMResourceLimitMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getAMResourceLimitPerPartition(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getAMResourceLimitVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getAMResourceRequests() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getAMResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getAMResourcesUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getAMResourceUsageMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Get the AM memory usage in MB.
getAMResourceUsageVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Get the AM VCore usage.
getAMRMToken() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The AMRMToken belonging to this app attempt
getAMRMToken() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getAMRMTokenKeyId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getAMRMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getAMRMTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAMRMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getAMRMTokenSecretManagerState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
getAmrmTokenSecretManagerState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAMRMTokenEvent
 
getAmRPCAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAmRPCAddressFromRMAppAttempt(RMAppAttempt) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAMUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getAMUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getAMUsed(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getAmUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getAMUsedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getAndCheckLeafQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
Check that the String provided in input is the name of an existing, LeafQueue, if successful returns the queue.
getAndIncrementEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
getAndIncrementEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
getAndIncrementEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
getAndIncrementEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
getAndIncrementEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Get the current epoch of RM and increment the value.
getAndIncrementEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
getAndResetBlacklistChanged() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getApp(HttpServletRequest, String, Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the report for a specific app, and it is reachable by using RMWSConsts.APPS_APPID.
getApp(HttpServletRequest, String, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppActivities(HttpServletRequest, String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the activities for a specific app for a specific period of time, and it is reachable by using RMWSConsts.SCHEDULER_APP_ACTIVITIES.
getAppActivities(HttpServletRequest, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppActivitiesInfo(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
getAppAMNodePartitionName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getAppAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncherEvent
 
getAppAttempt(HttpServletRequest, HttpServletResponse, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppAttemptDir(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
getAppAttemptId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Get the application attempt id for this RMAppAttempt.
getAppAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getAppAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getAppAttemptResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getAppAttempts() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
RMApp can have multiple application attempts RMAppAttempt.
getAppAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getAppAttempts(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the attempts information for a specific app, and it is reachable by using RMWSConsts.APPS_APPID_APPATTEMPTS.
getAppAttempts(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppAttemptState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAppAttemptEvent
 
getAppAttemptState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppAttemptEvent
 
getAppAttemptState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The state of the RMAppAttempt.
getAppAttemptState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getAppAttemptTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
The application attempt tokens that belong to this attempt
getAppAttemptTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getAppDir(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
getAppFairShare(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
Get the fair share assigned to the appAttemptId.
getAppId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeCleanAppEvent
 
getAppId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerPreemptEvent
 
getAppId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAppIdNum() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getApplicableNodeCountForAM(RMContext, Configuration, List<ResourceRequest>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Get applicable Node count for AM.
getApplication() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getApplicationACLsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getApplicationAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getApplicationAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getApplicationAttempt(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getApplicationAttemptFinishData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptFinishEvent
 
getApplicationAttemptHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptFinishEvent
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptStartEvent
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRemoveAppAttemptEvent
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptEvent
 
getApplicationAttemptId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptAddedSchedulerEvent
 
getApplicationAttemptID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptRemovedSchedulerEvent
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Get ApplicationAttemptId of the application master.
getApplicationAttemptReport(GetApplicationAttemptReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getApplicationAttemptReport(GetApplicationAttemptReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppAttemptBlock
 
getApplicationAttemptReport(GetApplicationAttemptReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getApplicationAttempts(GetApplicationAttemptsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getApplicationAttemptsReport(GetApplicationAttemptsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
getApplicationAttemptsReport(GetApplicationAttemptsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getApplicationAttemptStartData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptStartEvent
 
getApplicationFinishData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationFinishEvent
 
getApplicationHomeSubCluster(GetApplicationHomeSubClusterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationFinishEvent
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationStartEvent
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.TimelinePublishEvent
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppToMonitor
 
getApplicationId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The application id for this RMApp.
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppEvent
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManagerEvent
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithmOutput
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingResponse
Get Application Id.
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Get Application Id.
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.NotSelf
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getApplicationID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppRemovedSchedulerEvent
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewApplication
 
getApplicationIdsByTag(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplications
 
getApplicationMasterService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getApplicationMasterService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getApplicationMasterService() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getApplicationMasterService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getApplicationName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getApplicationPlacementContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Get the application -> queue placement context
getApplicationPlacementContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Get priority of the application.
getApplicationPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationReport(GetApplicationReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
It gives response which includes application report if the application present otherwise throws ApplicationNotFoundException.
getApplicationReport(GetApplicationReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
getApplicationReport(GetApplicationsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppsBlock
 
getApplicationReport(GetApplicationReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getApplicationResourceUsageReport() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Get application container and resource usage information.
getApplicationResourceUsageReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getApplications(GetApplicationsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
Get applications matching the GetApplicationsRequest.
getApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Obtain (read-only) collection of active applications.
getApplicationSchedulingEnvs() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Get the application scheduling environment variables.
getApplicationSchedulingEnvs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationSchedulingEnvs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getApplicationsHomeSubCluster(GetApplicationsHomeSubClusterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getApplicationsReport(GetApplicationsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getApplicationStartData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationStartEvent
 
getApplicationState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
The ApplicationSubmissionContext for the application ApplicationId can be obtained from the this
getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getApplicationSubmissionContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The application submission context for this RMApp
getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationTags() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Get tags for the application
getApplicationTags() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationTags() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getApplicationTags() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getApplicationTimeouts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getApplicationTimeouts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getApplicationTimeouts() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getApplicationTimeouts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationType() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Returns the application type
getApplicationType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getApplicationType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getApplicationType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getApplicatonPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getAppNodeLabelExpression() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getAppNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getAppNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getAppNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getAppOrderingPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getAppPlacementAllocator(String, AppSchedulingInfo, SchedulerRequestKey, RMContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ApplicationPlacementAllocatorFactory
Get AppPlacementAllocator related to the placement type requested.
getAppPlacementAllocator(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getAppPlacementAllocator(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getAppPlacementAllocator(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getAppPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getAppPriority(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the priority for a specific app, and it is reachable by using RMWSConsts.APPS_APPID_PRIORITY.
getAppPriority(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppProxyUrl(Configuration, ApplicationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAppProxyUrl(Configuration, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getAppQueue(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the queue for a specific app, and it is reachable by using RMWSConsts.APPS_APPID_QUEUE.
getAppQueue(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppResourceUsageReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getAppResourceUsageReport(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get a resource usage report from a given app attempt ID.
getApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
getApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppsInfo
 
getApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInformationsInfo
 
getApps(HttpServletRequest, String, Set<String>, String, String, String, String, String, String, String, String, Set<String>, Set<String>, Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the app reports in the cluster, and it is reachable by using RMWSConsts.APPS.
getApps(HttpServletRequest, String, Set<String>, String, String, String, String, String, String, String, String, Set<String>, Set<String>, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppSchedulingInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getAppsCompleted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAppsCompleted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAppsCompleted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAppsFailed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAppsFailed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAppsFailed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAppsInQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getAppsInQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getAppsInQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getAppsInQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Gets the apps under a given queue
getAppsKilled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAppsKilled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAppsKilled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAppsPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAppsPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAppsPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAppsRunning() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAppsRunning() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAppsRunning() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAppsSubmitted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAppsSubmitted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAppsSubmitted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getAppState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAppEvent
 
getAppState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRemoveAppEvent
 
getAppState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppEvent
 
getAppState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getAppState(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the state for a specific app, and it is reachable by using RMWSConsts.APPS_APPID_STATE.
getAppState(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppStatistics(HttpServletRequest, Set<String>, Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the statistics for a specific app, and it is reachable by using RMWSConsts.APP_STATISTICS.
getAppStatistics(HttpServletRequest, Set<String>, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppsToCleanup() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getAppsToCleanup() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getAppTimeout(HttpServletRequest, String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the timeout information for a specific app with a specific type, and it is reachable by using RMWSConsts.APPS_TIMEOUTS_TYPE.
getAppTimeout(HttpServletRequest, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppTimeouts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutsInfo
 
getAppTimeouts(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the timeout information for a specific app, and it is reachable by using RMWSConsts.APPS_TIMEOUTS.
getAppTimeouts(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppTimeoutType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppToMonitor
 
getArgs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.ArgsBuilder
 
getArrival() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
getAssignmentInformation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getAssignmentIterator(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.PriorityUtilizationQueueOrderingPolicy
 
getAssignmentIterator(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.QueueOrderingPolicy
Return an iterator over the collection of CSQueues which orders them for container assignment.
getAssignmentIterator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
getAssignmentIterator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Return an iterator over the collection of SchedulableEntity objects which orders them for container assignment.
getAssignMultiple() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getAssignMultipleEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getAsyncSchedulingPendingBacklogs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getAttemptCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getAttemptFailuresValidityInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
The ApplicationAttemptId for the application attempt
getAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptsInfo
 
getAutoCreatedQueueManagementPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
getAutoCreatedQueueManagementPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Queue Management computation policy for Auto Created queues
getAutoCreatedQueueManagementPolicyClass(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get The policy class configured to manage capacities for auto created leaf queues under the specified parent
getAutoCreatedQueuesMaxChildQueuesLimit(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get the max number of leaf queues that are allowed to be created under a parent queue
getAutoCreatedQueueTemplateConfPrefix(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get the auto created leaf queue's template configuration prefix Leaf queue's template capacities are configured at the parent queue
getAuxillaryServiceData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
getAvailableMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAvailableMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAvailableMemory() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getAvailableResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getAvailableResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNodeReport
 
getAvailableResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getAvailableResourceOverTime(String, ReservationId, long, long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getAvailableSchedulingMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
getAvailableVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAvailableVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getAvailableVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getAvailNodeCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getAverageCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the average allowed capacity which will aggregated over the ReservationSchedulerConfiguration.getReservationWindow(java.lang.String) by the the SharingPolicy to check aggregate used capacity
getAverageCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getAverageCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getAvgOverTimeMultiplier() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getBindAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
getBindAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getBindAddress(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Retrieve RM bind address from configuration
getBlacklist(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Get any blacklisted nodes associated with tag.
getBlackListCopy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getBlacklistedNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
 
getBlacklistedNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getBlacklistedNodes(SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Add blacklisted NodeIds to the list that is passed.
getBlacklistedNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getBlacklistUpdates() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.blacklist.BlacklistManager
Get ResourceBlacklistRequest that indicate which nodes should be added or to removed from the blacklist.
getBlacklistUpdates() - Method in class org.apache.hadoop.yarn.server.resourcemanager.blacklist.DisabledBlacklistManager
 
getBlacklistUpdates() - Method in class org.apache.hadoop.yarn.server.resourcemanager.blacklist.SimpleBlacklistManager
 
getCachedDemand(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getCachedPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getCachedPending(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getCachedUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getCachedUsed(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getCallerContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getCallerContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getCallerContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getCallerContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getCallerUGI() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppKillByClientEvent
returns the UserGroupInformation information.
getCallerUserGroupInformation(HttpServletRequest, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebAppUtil
Helper method to retrieve the UserGroupInformation from the HttpServletRequest.
getCancelTokensWhenComplete() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
getCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the configured capacity of the queue.
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getCapacityAtTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Get capacity at time based on periodic repetition.
getCapacityAtTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Returns the capacity, i.e.
getCapacityConfigType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getCapacityConfigType() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get CapacityConfigType as PERCENTAGE or ABSOLUTE_RESOURCE.
getCapacitySchedulerQueueManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getCapacitySchedulerQueueManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getChildQueues() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get child queues
getChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
getChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Gets the children of this queue, if any.
getChildQueues() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueue
Get list of child queues.
getChildQueues(FSQueue, FairScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getChildren() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
getChildren() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getChildReservationQueues(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Get a list of reservation queues for this planQueue.
getChildReservationQueues(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
getChildReservationQueues(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
getClientRMService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getClientRMService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getClientRMService() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getClientRMService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getClientToAMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getClientToAMTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getClientToAMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getClientTokenMasterKey() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The master key for client-to-AM tokens for this app attempt.
getClientTokenMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getClock() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getClock() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
Get clock from scheduler
getClusterCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
getClusterId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getClusterId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getClusterInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the cluster information, and it is reachable by using RMWSConsts.INFO.
getClusterInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getClusterMaxApplicationPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getClusterMaxApplicationPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getClusterMetrics(GetClusterMetricsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getClusterMetricsInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the cluster metrics information, and it is reachable by using RMWSConsts.METRICS.
getClusterMetricsInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getClusterNodeLabels(GetClusterNodeLabelsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getClusterNodeLabels(HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the node labels in the cluster, and it is reachable by using RMWSConsts.GET_NODE_LABELS.
getClusterNodeLabels(HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getClusterNodes(GetClusterNodesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getClusterResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getClusterResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getClusterResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSContext
 
getClusterResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get the whole resource capacity of the cluster.
getClusterResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getClusterResourceUsage() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getClusterTimeStamp() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getCollectorData() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The timeline collector information for the application.
getCollectorData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getCollectorInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The timeline collector information to be sent to AM.
getCollectorInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getCommandPort() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the command port for this node
getCommandPort() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getCommands() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
getComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
getComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
getComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
getComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
The comparator returned by this method is to be used for sorting the Schedulables in that queue.
getComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
getCompletedAppsListSize() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
getCompletedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getCompletedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.UpdatedContainerInfo
 
getCompletedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeResponse
 
getComputedResourceLimitForActiveUsers(String, Resource, String, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Get computed user-limit for all ACTIVE users in this queue.
getComputedResourceLimitForAllUsers(String, Resource, String, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Get computed user-limit for all users in this queue.
getConf() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
getConf() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getConf() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
Get the yarn configuration.
getConf() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getConf() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getConfigName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.PriorityUtilizationQueueOrderingPolicy
 
getConfigName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.QueueOrderingPolicy
Returns configuration name (which will be used to set ordering policy
getConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getConfiguration() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getConfiguration() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfScheduler
Get the scheduler configuration.
getConfigurationProvider() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getConfigurationProvider() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getConfigurationProvider() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getConfigurationsWithPrefix(SortedMap<String, String>, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
getConfiguredMaxResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getConfiguredMaxResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getConfiguredMaxResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getConfiguredMinResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getConfiguredMinResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getConfiguredMinResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getConfiguredNodeLabels(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get configured node labels in a given queuePath
getConfiguredQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getConfiguredQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getConfiguredState(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getConfirmedConfHistory(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
getConfirmedConfHistory(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
getConfirmedConfHistory(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Get a list of confirmed configuration mutations starting from a given id.
getConfirmedConfHistory(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
getConfStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
getConfStoreVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
getConfStoreVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
getConfStoreVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Get schema version of persisted conf store, for detecting compatibility issues when changing conf store schema.
getConfStoreVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
getConstraint(ApplicationId, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
getConstraint(ApplicationId, Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Retrieve the placement constraint that is associated with a set of allocation tags for a given application.
getConstraints(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
getConstraints(ApplicationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Retrieve all constraints for a given application, along with the allocation tags that enable each constraint.
getConsumedAMResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getConsumedAMResources(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getConsumptionForUserOverTime(String, long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getContainer() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerPreemptEvent
 
getContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ReleaseContainerEvent
Get RMContainer.
getContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the container for the specified container ID.
getContainer(HttpServletRequest, HttpServletResponse, String, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getContainerAllocationExpirer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getContainerAllocationExpirer() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getContainerAllocationExpirer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getContainerExitStatus() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getContainerExitStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getContainerFinishData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerFinishEvent
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerFinishEvent
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerStartEvent
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
getContainerId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerEvent
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeCleanContainerEvent
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerExpiredSchedulerEvent
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth.DetailedInformation
 
getContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo.OperationInformation
 
getContainerLaunchContextInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getContainerMgrProxy(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
getContainerNodeType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
getContainerPreemptions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getContainerReport(GetContainerReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getContainerReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerRecoverEvent
 
getContainerReport(GetContainerReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
getContainerReport(GetContainerReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMContainerBlock
 
getContainerReport(GetContainerReportRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getContainerReports() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeAddedSchedulerEvent
 
getContainerRequest() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getContainerRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getContainers(GetContainersRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeFinishedContainersPulledByAMEvent
 
getContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getContainers(GetContainersRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppAttemptBlock
 
getContainers(HttpServletRequest, HttpServletResponse, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getContainersAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getContainersCPUUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
getContainersReport(GetContainersRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getContainerStartData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerStartEvent
 
getContainerState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getContainerState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getContainerStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerFinishedEvent
 
getContainersToAllocate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getContainersToCleanUp() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getContainersToCleanUp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getContainersToCleanUp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeResponse
 
getContainersToKill() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getContainersToRelease() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getContainersToReserve() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getContainerToBeUnreserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
getContainerTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getContainerTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getContainerTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getContainerTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getContainerTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getContainerTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
getContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getContext(Class<?>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.JAXBContextResolver
 
getContinuousSchedulingSleepMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
getContinuousSchedulingSleepMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
getCopiedListOfRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the containers running on the node.
getCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.PendingAsk
 
getCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo.LastRunDetails
 
getCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
getCreationTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getCreationTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getCredentials() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
getCredentialsFromAppAttempt(RMAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
getCSAssignmentFromAllocateResult(Resource, ContainerAllocation, RMContainer, FiCaSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.AbstractContainerAllocator
 
getCSLeafQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getCumulative() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
getCumulativeLoadOverTime(long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getCurator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getCuratorClient() - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
getCurrentAppAttempt() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
RMApp can have multiple application attempts RMAppAttempt.
getCurrentAppAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getCurrentAppAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getCurrentApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
getCurrentApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplications
 
getCurrentAttemptForContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getCurrentConsumption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getCurrentIndex() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner.StageProvider
 
getCurrentMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
AMRMTokenSecretManager current Master key
getCurrentMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
getCurrentReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Get total current reservations.
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Get the current version of the underlying state store.
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Get the hard-coded schema version, for comparison against the schema version currently persisted.
getCurrentVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
getCurrnetMasterKeyData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
getDeadline() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
getDecommissionedNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getDecommissioningNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getDecommissioningTimeout() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getDecommissioningTimeout() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeDecommissioningEvent
 
getDecommissioningTimeout() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getDecreasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getDecreaseRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdates
Returns Container Decrease Requests.
getDefaultApplicationLifetime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getDefaultApplicationPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getDefaultApplicationPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getDefaultApplicationPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getDefaultApplicationPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get the Default Application Priority for this queue
getDefaultApplicationPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getDefaultApplicationPriorityConfPerQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getDefaultFairSharePreemptionThreshold() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getDefaultFairSharePreemptionTimeout() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getDefaultLifetimePerQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getDefaultMaximumKillWaitTimeout() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getDefaultMaximumKillWaitTimeout() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getDefaultMinSharePreemptionTimeout() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getDefaultNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getDefaultNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getDefaultNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getDefaultNodeLabelExpression() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get default label expression of this queue.
getDefaultNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getDefaultPermissions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
Returns the list of default permissions.
getDefaultPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
getDefaultPriority(String, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AppPriorityACLsManager
If an application is submitted without any priority, and submitted user has a default priority, this method helps to update this default priority as app's priority.
getDefaultPriorityForQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
Get the default priority of the queue.
getDefaultProfile() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Get default supported resource profile.
getDefaultProfile() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
getDefaultReservationSystem(ResourceScheduler) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
Get the default reservation system corresponding to the scheduler
getDefaultSchedulingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getDefaultSchedulingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getDelegationKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTMasterKeyEvent
 
getDelegationToken(GetDelegationTokenRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getDelegationTokenRenewer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getDelegationTokenRenewer() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getDelegationTokenRenewer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getDelegationTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
getDeltaCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
Delta capacity = target - before, so if it is a decrease request, delta capacity will be negative
getDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
getDemand() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Maximum number of resources required by this Schedulable.
getDemandResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getDemotedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getDemotionRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdates
Returns Container Demotion Requests.
getDiagnostic() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getDiagnostic() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getDiagnosticMessage() - Method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt.AMState
 
getDiagnosticMsg() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptEvent
 
getDiagnosticMsg() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppEvent
 
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the diagnositic information of the attempt
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
Get the diagnostics information for the application master.
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getDiagnostics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Diagnostics information for the application attempt.
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getDiagnostics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
the diagnostics information for the application master.
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppState
 
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
getDiagnosticsInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getDiagnosticsInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher
 
getDispatcher() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getDTSequenceNumber() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
getDuration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
getDurationInterval(long, long, RLESparseResourceAllocation, RLESparseResourceAllocation, Resource, RLESparseResourceAllocation, ResourceCalculator, long, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
getDurationIntervalGangsCanFit(long, long, RLESparseResourceAllocation, Resource, RLESparseResourceAllocation, ResourceCalculator, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
getDurationIntervalTotalCost(long, long, RLESparseResourceAllocation, RLESparseResourceAllocation, Resource, ResourceCalculator, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
getEarliestStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getEarliestStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Get the timestamp of the earliest resource allocation.
getEffectiveCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getEffectiveCapacity(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get effective capacity of queue.
getEffectiveCapacityDown(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getEffectiveCapacityDown(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get effective capacity of queue.
getEffectiveMaxCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getEffectiveMaxCapacity(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get effective max capacity of queue.
getEffectiveMaxCapacityDown(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getEffectiveMaxCapacityDown(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get effective max capacity of queue.
getEffectiveMaxResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getEffectiveMaxResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getEffectiveMaxResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getEffectiveMinResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getEffectiveMinResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
getEffectiveMinResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getElapsedTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getEnableUserMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getEndTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getEndTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
getEndTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the time at which the reservation terminates.
getEndTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
Get the end time of the reservation interval
getEndTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
getEnforceExecutionType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ExecutionTypeRequestInfo
 
getEnforcementWindow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the time in milliseconds for which the Planner will verify the Plans satisfy the constraints
getEnforcementWindow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getEnforcementWindow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getEnforcementWindowMsec() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getEnvironment() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
getEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
getEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.EpochPBImpl
 
getEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getEpoch() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getEpoch() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getEventHandler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter.MultiThreadedDispatcher
 
getEventHandler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.MultiThreadedDispatcher
 
getExcessReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getExcludePattern() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
getExclusivity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
getExecutionType() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getExecutionType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getExecutionType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ExecutionTypeRequestInfo
 
getExecutionTypeRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getExistingNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getExpireChecker() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
getExpireTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
getExplanation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMFatalEvent
Get a text description of the reason for the event.
getFairShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getFairShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Get the fair share assigned to this Schedulable.
getFairShare() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Get the fair share assigned to this Schedulable.
getFairShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the fair share of this queue in megabytes
getFairShareMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getFairShareMemoryFraction() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the fair share as a fraction of the entire cluster capacity.
getFairSharePreemptionThreshold(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
Get a queue's fair share preemption threshold in the allocation file.
getFairSharePreemptionThresholds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getFairSharePreemptionTimeout(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
Get a queue's fair share preemption timeout configured in the allocation file, in milliseconds.
getFairSharePreemptionTimeouts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getFairShareVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getFederationStateStoreService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getFiCaSchedulerApp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
getFinalAllocationState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
getFinalApplicationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the final finish status of the application.
getFinalApplicationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getFinalApplicationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptUnregistrationEvent
 
getFinalApplicationStatus() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The final status set by the AM.
getFinalApplicationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getFinalApplicationStatus() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The final finish state of the AM when unregistering as in FinishApplicationMasterRequest.setFinalApplicationStatus(FinalApplicationStatus).
getFinalApplicationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getFinalAttemptState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptRemovedSchedulerEvent
 
getFinalState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppRemovedSchedulerEvent
 
getFinalStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getFinalTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the original not-proxied final tracking url for the application.
getFinalTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getFinalTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptUnregistrationEvent
 
getFinishedApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeResponse
 
getFinishedContainersSentToAMReference() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The map of conatiners per Node that are already sent to the AM.
getFinishedContainersSentToAMReference() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getFinishedTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the finish time of the application attempt.
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
The finish time of the application.
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getFinishTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
the finish time of the application attempt.
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getFinishTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The finish time of the RMApp
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getFinishTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getFinishTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getFirstAllocatedOrReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getFirstAllocatedOrReservedContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getFirstAllocatedOrReservedRMContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getFirstAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getFulfilledReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getGlobalConstraint(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
getGlobalConstraint(Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Retrieve a global constraint that is associated with a given set of allocation tags.
getGlobalMaximumApplicationsPerQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getGroupsForUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
getGuaranteed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
getHadoopBuildVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getHadoopVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getHadoopVersionBuiltOn() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getHAServiceState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getHAServiceState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getHAServiceState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getHAState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getHAZookeeperConnectionState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getHAZookeeperConnectionState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getHAZookeeperConnectionState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getHAZookeeperConnectionState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getHAZookeeperConnectionState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
getHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityHeadroomProvider
 
getHeadroom(UsersManager.User, Resource, Resource, FiCaSchedulerApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getHeadroom(UsersManager.User, Resource, Resource, FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
Headroom depends on resources in the cluster, current usage of the queue, queue's fair-share and queue's max-resources.
getHeadroom(Resource, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
getHeadroom(Resource, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
getHeadroom(Resource, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
getHeadroom(Resource, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Get headroom by calculating the min of clusterAvailable and (queueFairShare - queueUsage) resources that are applicable to this policy.
getHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
getHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Get available headroom in terms of resources for the application's user.
getHealthReport() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the latest health report received from this node.
getHealthReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getHealthReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getHost() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptRegistrationEvent
 
getHost() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The host on which the RMAppAttempt is running/ran on.
getHost() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getHostName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the hostname of this node
getHostName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getHostsReader() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
getHttpAddress() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the http-Address for this node.
getHttpAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getHttpAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get HTTP address for the node.
getHttpPort() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the http port for this node
getHttpPort() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getId() - Method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser.AppPriorityACLKeyType
 
getId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.SchedulableEntity
Id - each entity must have a unique id
getId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getIdealAssigned() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
getIgnoreExclusivityRMContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getInactiveRMNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getInactiveRMNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getInactiveRMNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getIncludePattern() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
getIncreasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getIncreaseRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdates
Returns Container Increase Requests.
getIncrementAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getIncrementResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getIndex() - Method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeType
 
getInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
getInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
getInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicy
 
getInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FifoOrderingPolicyForPendingApps
 
getInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Return information regarding configuration and status.
getInitialLeafQueueConfiguration(AbstractAutoCreatedLeafQueue) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedQueueManagementPolicy
Get initial template for the specified leaf queue
getInitialLeafQueueConfiguration(AbstractAutoCreatedLeafQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
getInstance(boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSOpDurations
 
getInstance(Class<? extends SchedulingPolicy>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Returns a SchedulingPolicy instance corresponding to the passed clazz.
getInstance() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.security.authorize.RMPolicyProvider
 
getInstantaneousMaxCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the maximum capacity at any time that the SharingPolicy allows
getInstantaneousMaxCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getInstantaneousMaxCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getIntraQueuePreemptionDisabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getIntraQueuePreemptionDisabled(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Indicates whether intra-queue preemption is disabled on the specified queue
getIntraQueuePreemptionDisabled() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Check whether intra-queue preemption is disabled for this queue
getIntraQueuePreemptionDisabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getIntraQueuePreemptionDisabledInHierarchy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getIntraQueuePreemptionDisabledInHierarchy() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Determines whether or not the intra-queue preemption disabled switch is set at any level in this queue's hierarchy.
getIntraQueuePreemptionOrderPolicy() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getIntraQueuePreemptionOrderPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getIp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppKillByClientEvent
returns the ip address stored in this event.
getIsActive() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getIsAppRecovering() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getIsAttemptRecovering() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptAddedSchedulerEvent
 
getIsPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getIteratorType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Get Iterator type.
getJustFinishedContainers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Return the list of last set of finished containers.
getJustFinishedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getJustFinishedContainersReference() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Returns a reference to the map of last set of finished containers to the corresponding node.
getJustFinishedContainersReference() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getKeepAliveAppIds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getKeepContainersAcrossAppAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptRemovedSchedulerEvent
 
getKeepContainersAcrossApplicationAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getKillableContainers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getKillableContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getKillableContainers(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getKillableContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptableQueue
 
getKillableContainers(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
getKillableContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getKillableContainersMap(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
getKillableResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptableQueue
 
getKillableResource(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
getKind() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
getLabeledQueueCapacity(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getLabeledQueueMaximumCapacity(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the labels for the node.
getLabelsOnNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
getLabelsOnNode(HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the node labels for specific node, and it is reachable by using RMWSConsts.NODES_NODEID_GETLABELS.
getLabelsOnNode(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getLabelsToNodes(GetLabelsToNodesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getLabelsToNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LabelsToNodesInfo
 
getLabelsToNodes(Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the node within multiple node labels in the cluster, and it is reachable by using RMWSConsts.LABEL_MAPPINGS.
getLabelsToNodes(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getLastAllocationDetails() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getLastConfirmedResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getLastConfirmedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getLastEndTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getLastHealthReportTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the time of the latest health report received from this node.
getLastHealthReportTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getLastHealthUpdate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getLastHeartbeatMonotonicTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
getLastNodeHeartBeatResponse() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getLastNodeHeartBeatResponse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getLastNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.PendingAskUpdateResult
 
getLastNodeUpdateTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getLastNodeUpdateTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getLastPendingAsk() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.PendingAskUpdateResult
 
getLastPreemptionDetails() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getLastReleaseDetails() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getLastReservationDetails() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getLastrun() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo
 
getLastScheduledContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getLastSchedulerRunTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getLatestDTSequenceNumber() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getLatestNonNullTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Get the timestamp of the latest non-null resource allocation.
getLaunchedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getLazyPreemptionEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getLeaderElectorService() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getLeaderElectorService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getLeaderElectorService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getLeafQueue(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a leaf queue by name, creating it if the create param is true and is necessary.
getLeafQueue(String, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getLeafQueueConfigPrefix(CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
getLeafQueueConfigs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig
 
getLeafQueueConfigs(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
getLeafQueueConfigs(CapacitySchedulerConfiguration, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
getLeafQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.KillableContainer
 
getLeafQueueNames() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getLeafQueueNames() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getLeafQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a collection of all leaf queues
getLeafQueueTemplate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
getLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
getLiveContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Get the live containers of the application.
getLiveContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppReport
Get the list of live containers
getLiveContainersMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getLiveNodeManagers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMNMInfo
Implements getLiveNodeManagers()
getLiveNodeManagers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMNMInfoBeans
 
getLoadAtTime(long, RLESparseResourceAllocation, RLESparseResourceAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
getLocalityDelayNodeMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
getLocalityDelayRackMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
getLocalityStatistics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getLocalityThresholdNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getLocalityThresholdRack() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getLocalityWaitFactor(int, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.RegularContainerAllocator
 
getLogAggregationContextInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getLogAggregationFailureMessagesForNM(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getLogAggregationPolicyClassName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
getLogAggregationPolicyParameters() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
getLogAggregationReportsForApp() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getLogAggregationReportsForApp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getLogAggregationReportsForApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStartedEvent
 
getLogAggregationReportsForApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getLogAggregationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getLogAggregationStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
getLogAggregationStatusForAppReport() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getLogAggregationStatusForAppReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getLogs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
getLogs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
getLogsLink() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getLogURL() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getLogURL() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getLostNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getManagedParentQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getMasterContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
getMasterContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getMasterContainer() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The container on which the Application Master is running.
getMasterContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
getMasterKey(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
getMasterKeyState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
getMasterNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getMax() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
getMaxAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getMaxAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getMaxAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getMaxAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
getMaxAllowableLimitForIntraQueuePreemption() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getMaxAllowableLimitForIntraQueuePreemption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getMaxAllowedAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
getMaxAMLimitPercentage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getMaxAMResourcePercentage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getMaxAMResourcePercentage(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getMaxAMResourcePerQueuePercent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Used only by tests.
getMaxAMShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMaxAMShareMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Get the maximum memory size AM can use in MB.
getMaxAMShareVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Get the maximum number of VCores AM can use.
getMaxAppAttempts() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The number of max attempts of the application.
getMaxAppAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getMaxAppAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getMaxApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getMaxApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getMaxApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getMaxApplicationsForReservations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
Number of maximum applications for each of the reservations in this Plan.
getMaxApplicationsPerUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getMaxApplicationsPerUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getMaxApplicationsPerUserForReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
Number of maximum applications per user for each of the reservations in this Plan.
getMaxApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getMaxAssign() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getMaxAssignPerHeartbeat() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
getMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getMaxChildQueueResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMaxChildQueueResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getMaxClusterLevelAppPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getMaxClusterLevelAppPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getMaxClusterLevelAppPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get cluster max priority.
getMaxClusterLevelAppPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
getMaxEffectiveCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getMaxIgnoreOverCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getMaxIgnoreOverCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getMaximumAllocation() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Returns the single largest Resource allocation that can be reserved in this plan
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Get a Resource object with for the maximum allocation possible.
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getMaximumAllocationPerQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get the per queue setting for the maximum limit to allocate to each container request.
getMaximumAMResourcePercentPerPartition(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaximumApplicationLifetime(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getMaximumApplicationLifetime(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getMaximumApplicationLifetime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getMaximumApplicationLifetime(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get maximum lifetime for a queue.
getMaximumApplicationMasterResourcePercent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaximumApplicationMasterResourcePerQueuePercent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get the maximum am resource percent per queue setting.
getMaximumApplicationsPerQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get the maximum applications per queue setting.
getMaximumCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getMaximumCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the configured maximum-capacity of the queue.
getMaximumCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getMaximumCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getMaximumKillWaitTimeMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptionCandidatesSelector
 
getMaximumLifetimePerQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaximumPeriodicCapacity(long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Get maximum capacity at periodic offsets from the specified time.
getMaximumPeriodicCapacity(long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Get the maximum capacity across specified time instances.
getMaximumPeriodicity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getMaximumPeriodicity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Returns the maximum periodicity allowed in a recurrence expression for reservations of a particular plan.
getMaximumProfile() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Get maximum supported resource profile.
getMaximumProfile() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
getMaximumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getMaximumResourceCapability(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getMaximumResourceCapability(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getMaximumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getMaximumResourceCapability(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getMaximumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get maximum allocatable Resource at the cluster level.
getMaximumResourceCapability(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get maximum allocatable Resource for the queue specified.
getMaximumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewApplication
 
getMaximumResourceRequirement(String, String, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get absolute maximum resource requirement for a queue.
getMaximumSystemApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaxLeavesToBeActivated(float, float, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
getMaxOverTimeMultiplier() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getMaxPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
getMaxQueueMemoryCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getMaxQueueResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
getMaxQueueResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getMaxResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getMaxResourcesFraction() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the capacity of this queue as a fraction of the entire cluster capacity.
getMaxRunningApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMaxShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getMaxShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMaxShare() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Maximum Resource share assigned to the schedulable.
getMaxShareMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getMaxShareVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getMaxValidity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
getMemoryPerNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
getMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the memory seconds (in MB seconds) of the application.
getMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AggregateAppResourceUsage
 
getMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getMemorySize() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
getMetric(NodeQueueLoadMonitor.ClusterNode) - Method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor.LoadComparator
 
getMetrics() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getMetrics() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
getMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
Get metrics reference from containing queue.
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSOpDurations
 
getMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMetrics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get the queue metrics
getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getMetricsSystem() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getMinAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getMinAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getMinAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getMinAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
getMinConcurrency() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
getMinEffectiveCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getMinimumAllocation() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Returns the single smallest Resource allocation that can be reserved in this plan
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getMinimumAllocationFactor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Used only by tests.
getMinimumCapacityInInterval(ReservationInterval) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Get the minimum capacity in the specified time range.
getMinimumProfile() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Get minimum supported resource profile.
getMinimumProfile() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
getMinimumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getMinimumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getMinimumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get minimum allocatable Resource.
getMinimumResourceRequirement(String, String, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get absolute minimum resource requirement for a queue.
getMinimumThresholdForIntraQueuePreemption() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getMinimumThresholdForIntraQueuePreemption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getMinQueueMemoryCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getMinQueueResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
getMinQueueResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getMinResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getMinShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getMinShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMinShare() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Minimum Resource share assigned to the schedulable.
getMinShareMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getMinSharePreemptionTimeout(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
Get a queue's min share preemption timeout configured in the allocation file, in milliseconds.
getMinSharePreemptionTimeouts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getMinShareVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getMonitoringInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getMonitoringInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
getMonitoringInterval() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
 
getMonitoringInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getMoveOnExpiry() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getMoveOnExpiry() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Instructs the PlanFollower on what to do for applications which are still running when the reservation is expiring (move-to-default vs kill)
getMoveOnExpiry(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets whether the applications should be killed or moved to the parent queue when the ReservationDefinition expires
getMoveOnExpiry(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMoveOnExpiry(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getMultilevelConstraint(ApplicationId, Set<String>, PlacementConstraint) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
getMultilevelConstraint(ApplicationId, Set<String>, PlacementConstraint) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Consider all levels of constraints (scheduling request, app, cluster) and return a merged constraint.
getMutableConfProvider() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getMutableConfProvider() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfScheduler
Get scheduler's configuration provider, so other classes can directly call mutation APIs on configuration provider.
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule
 
getName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The name of the application as set in ApplicationSubmissionContext.setApplicationName(String).
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AllocationActivity
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
getName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Name of job/queue, used for debugging as well as for breaking ties in scheduling order deterministically.
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
getNamespace() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
getNamespaceScope() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
Get the scope of the namespace, in form of a set of applications.
getNamespaceType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
Get the type of the namespace.
getNaturalTerminationFactor() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getNaturalTerminationFactor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getNewApplication(GetNewApplicationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getNewContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getNewContainerId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getNewlyLaunchedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.UpdatedContainerInfo
 
getNewNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.PendingAskUpdateResult
 
getNewPendingAsk() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.PendingAskUpdateResult
 
getNewReservation(GetNewReservationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getNewReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getNewReservationId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Get a new unique ReservationId.
getNextAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getNextExpirationTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
getNextKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
getNextKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
 
getNextMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
AMRMTokenSecretManager next Master key
getNextMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
getNextMasterKeyData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
getNextPendingAsk() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getNMContainerResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerNMDoneChangeResourceEvent
 
getNMContainerStatuses() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeReconnectEvent
 
getNMContainerStatuses() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStartedEvent
 
getNMReportedIncreasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getNMTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getNMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getNMTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getNMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManagerEvent
 
getNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent
 
getNode() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the Node information for this node.
getNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getNode(NodeId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
getNode(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves a specific node information, and it is reachable by using RMWSConsts.NODES_NODEID.
getNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getNodeAddress() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the ContainerManager address for this node.
getNodeAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getNodeCardinality(NodeId, ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Get Node cardinality for a specific tag.
getNodeCardinalityByOp(NodeId, AllocationTags, LongBinaryOperator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Get cardinality for following conditions.
getNodeCPUUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
getNodeHealthStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getNodeHttpAddress() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getNodeHttpAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getNodeHttpAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getNodeHTTPAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerFinishedEvent
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRunningOnNodeEvent
 
getNodeId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getNodeID() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the node id of of this node.
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeEvent
 
getNodeID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth.DetailedInformation
 
getNodeID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the ID of the node which contains both its hostname and port.
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo.OperationInformation
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getNodeId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntry
 
getNodeIds(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getNodeIds(NodeFilter) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
Convenience method to filter nodes based on a condition.
getNodeIds(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler
Get the NodeId available in the cluster by resource name.
getNodeIDs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeIDsInfo
 
getNodeIdsByResourceName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
Convenience method to return list of NodeId corresponding to resourceName passed in the ResourceRequest.
getNodeIdToUnreserve(SchedulerRequestKey, Resource, ResourceCalculator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getNodeLabelExpression() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getNodeLabelExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getNodeLabelManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getNodeLabelManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getNodeLabelManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getNodeLabels(Set<NodeId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsMappingProvider
Provides the labels.
getNodeLabels() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
Get set of labels in this node
getNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
getNodeLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntry
 
getNodeLabelsForQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getNodeLabelsForQueue() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get valid Node Labels for this queue
getNodeLabelsInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
getNodeLabelsName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
getNodeLocalityDelay() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getNodeLocalityDelay() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getNodeLocalityDelayMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
getNodeLocalityThreshold() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getNodeManagerQueueLimitCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
getNodeManagerQueueLimitCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getNodeManagerQueueLimitCalculator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getNodeManagerQueueLimitCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getNodeManagerVersion() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the node manager version of the node received as part of the registration with the resource manager
getNodeManagerVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getNodeName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the name of the node for scheduling matching decisions.
getNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.KillableContainer
 
getNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
getNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getNodePartitionsSet() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
getNodePartitionsSet() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getNodePhysicalMemoryMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
getNodeRemovalCheckInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
getNodeReport(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getNodeReport(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
getNodeReport(NodeId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get node resource usage report.
getNodeResourceMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
getNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
getNodes(NodeFilter) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getNodes(NodeFilter) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
Convenience method to filter nodes based on a condition.
getNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.PlacedSchedulingRequest
List of Node locations on which this Scheduling Request can be placed.
getNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodesInfo
 
getNodes(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the nodes information in the cluster, and it is reachable by using RMWSConsts.NODES.
getNodes(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getNodesByResourceName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
Convenience method to return list of nodes corresponding to resourceName passed in the ResourceRequest.
getNodesListManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getNodesListManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getNodesListManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getNodeToLabels(GetNodesToLabelsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getNodeToLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntryList
 
getNodeToLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsInfo
 
getNodeToLabels(HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves all the node labels with the respective nodes in the cluster, and it is reachable by using RMWSConsts.GET_NODE_TO_LABELS.
getNodeToLabels(HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getNodeTracker() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getNodeUtilization() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the total resource utilization of the node.
getNodeUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getNodeUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getNodeUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the resource utilization of the node.
getNodeVirtualMemoryMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
getNonLabeledQueueCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getNonLabeledQueueMaximumCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getNonPreemptableQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getNormalizedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getNormalizedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getNormalizedResource(Resource, ResourceCalculator, Resource, Resource, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility method to normalize a resource request, by insuring that the requested memory is a multiple of increment resource and is not zero.
getNormalizedResource(Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Normalize a resource request.
getNote() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getNumActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getNumActiveApplications(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getNumActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getNumActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getNumActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerLeafQueueInfo
 
getNumActiveApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
TODO: Based on how frequently this is called, we might want to club counting pending and active apps in the same method.
getNumActiveNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumActiveUsers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractUsersManager
Get number of active users i.e.
getNumActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
Get number of active users i.e.
getNumActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
getNumAllocations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getNumAMContainerPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getNumAMContainersPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getNumAMContainersPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getNumApplications() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the number of applications in the queue.
getNumApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getNumApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getNumApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getNumClusterNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getNumClusterNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getNumClusterNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getNumClusterNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getNumClusterNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get the number of nodes available in the cluster.
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeReport
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get number of active containers on the node.
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNodeReport
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getNumDecommisionedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumDecommissioningNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumFailedAppAttempts() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getNumGlobalConstraints() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
getNumGlobalConstraints() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Returns the number of global constraints registered in the Placement Constraint Manager.
getNumLostNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getNumNodesInRack(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getNumNonAMContainerPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getNumNonAMContainersPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getNumNonAMContainersPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getNumNonAMContainersPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getNumOfAllocates() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
getNumOfCommitSuccess() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
getNumOfNodeUpdate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerMetrics
 
getNumPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getNumPendingApplications(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getNumPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getNumPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getNumPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerLeafQueueInfo
 
getNumPendingApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getNumQueuedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getNumRebootedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumRegisteredApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
getNumRegisteredApplications() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Returns the number of currently registered applications in the Placement Constraint Manager.
getNumReservations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getNumReservedContainers(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getNumRetries() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
getNumRunnableApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getNumRunnableApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
getNumRunnableApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Return the number of apps for which containers can be allocated.
getNumRunningOpportContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getNumSchedulableEntities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
getNumSchedulableEntities() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Get the number of SchedulableEntity objects managed for allocation and preemption ordering.
getNumShutdownNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getOffSwitchPerHeartbeatLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getOperation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo.LastRunDetails
 
getOpportunisticContainerContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getOpportunisticContainersStatus() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getOpportunisticContainersStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getOpportunisticContainersStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getOrDefault(Map<String, Long>, String, Long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
getOrderingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getOrderingPolicyInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getOriginalTotalCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getOriginalTrackingUrl() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The original url at which the status of the application attempt can be accessed.
getOriginalTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getOriginalTrackingUrl() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The original tracking url for the application master.
getOriginalTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getOtherApplicationIds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplications
 
getOutstandingAsksCount(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Get #pending-allocations for given resourceName.
getOutstandingAsksCount(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
getOutstandingAsksCount(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
getOutstandingAsksCount(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getOutstandingAsksCount(SchedulerRequestKey, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getOverCommitTimeoutPerNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
getOverrideWithQueueMappings() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getOwner() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
getParent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getParent() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the parent Queue.
getParent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getParent() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueue
Get the parent queue.
getParentName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getParentQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext
 
getParentQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
getParentQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.QueueManagementChangeEvent
 
getParentQueue(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a parent queue by name, creating it if the create param is true and is necessary.
getParentQueue(String, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getPartition() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.CandidateNodeSet
Node partition of the node set.
getPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SimpleCandidateNodeSet
 
getPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get partition of which the node belongs to, if node-labels of this node is empty or null, it belongs to NO_LABEL partition.
getPartitionName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getPartitionName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getPartitionQueueCapacitiesInfo(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
getPartitionResource(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getPartitionResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getPartitionResourceUsageInfo(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourcesInfo
 
getPartitionResourceUsages() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourcesInfo
 
getPattern() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
getPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getPending(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getPendingAppDiagnosticMessage(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getPendingAppDiagnosticMessage(StringBuilder) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Obtain (read-only) collection of pending applications.
getPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
getPendingApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getPendingAppsOrderingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getPendingAsk(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getPendingAsk(SchedulerRequestKey, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getPendingAsk(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Get pending ask for given resourceName.
getPendingAsk(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
getPendingAsk(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
getPendingAsk(SchedulerRequestKey, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getPendingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getPendingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getPendingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getPendingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getPendingMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getPendingMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getPendingRelease() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getPendingResourceRequestsForAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getPendingResourceRequestsForAttempt(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
 
getPendingVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getPendingVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getPerAllocationResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.PendingAsk
 
getPerAppNodeMappings() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
 
getPeriodicity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getPeriodicity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Get the periodicity of this reservation representing the time period of the periodic job.
getPhysicalResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the physical resources in the node.
getPhysicalResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getPlacedRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithmOutput
 
getPlacementAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.PlacedSchedulingRequest
 
getPlacementAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingRequestWithPlacementAttempt
 
getPlacementAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Get placement attempt.
getPlacementConstraintManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getPlacementConstraintManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getPlacementConstraintManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getPlacementContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getPlacementForApp(ApplicationSubmissionContext, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule
Get queue for a given application
getPlacementForApp(ApplicationSubmissionContext, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule
 
getPlacementPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getPlacementRule(String, Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementFactory
 
getPlacementRules() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementManager
 
getPlan(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getPlan(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getPlan(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Get an existing Plan that has been initialized.
getPlanFollowerTimeStep() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getPlanFollowerTimeStep() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Return the time step (ms) at which the PlanFollower is invoked
getPlanName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreStoreReservationEvent
 
getPlanName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getPlanName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Return a string identifying the plan to which the reservation belongs
getPlanner() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getPlanQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Get queue associated with reservable queue named.
getPlanQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
getPlanQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
getPlanQueueCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getPlanQueueCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getPlanQueueCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getPlanQueuePath(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getPlanQueuePath(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getPlanQueuePath(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getPlanQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getPlanQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getPlanQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getPlanQueues() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Gets the list of names for queues managed by the Reservation System
getPlanResources(Plan, Queue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Get plan resources for this planQueue.
getPlanResources(Plan, Queue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
getPlanResources(Plan, Queue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
getPoliciesConfigurations(GetSubClusterPoliciesConfigurationsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getPolicy(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ConfigurationMutationACLPolicyFactory
 
getPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getPolicyConfiguration(GetSubClusterPolicyConfigurationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getPolicyName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getPolicyName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
getPolicyName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
 
getPolicyName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getPreemptableApps(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
getPreemptedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptedMemory() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getPreemptedMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the preempted memory seconds (in MB seconds) of the application.
getPreemptedMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getPreemptedMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getPreemptedMemorySeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptedResourceMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptedResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the aggregated number of resources preempted that the application has allocated times the number of seconds the application has been running.
getPreemptedResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getPreemptedResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getPreemptedResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getPreemptedResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptedResourceVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptedVcore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getPreemptedVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptedVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the preempted vcore seconds of the application.
getPreemptedVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getPreemptedVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getPreemptedVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPreemptionCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getPreemptionDisabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getPreemptionDisabled(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Indicates whether preemption is disabled on the specified queue.
getPreemptionDisabled() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Check whether disable_preemption property is set for this queue
getPreemptionDisabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getPreemptionEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getPreemptionIterator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
getPreemptionIterator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Return an iterator over the collection of SchedulableEntity objects which orders them for preemption.
getPreemptionManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getPreemptionManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getPreemptionUtilizationThreshold() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getPreferredNodeIterator(CandidateNodeSet<N>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Get iterator of preferred node depends on requirement and/or availability.
getPreferredNodeIterator(CandidateNodeSet<N>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
getPreferredNodeIterator(CandidateNodeSet<N>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
getPreviousAttemptContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getPrimaryRequestedNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
It is possible that one request can accept multiple node partition, So this method returns primary node partition for pending resource / headroom calculation.
getPrimaryRequestedNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
getPrimaryRequestedNodePartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get priority of queue
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Job priority for jobs in FIFO queues; meaningless for QueueSchedulables.
getPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.SchedulableEntity
Get the priority of the application
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppPriority
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getPriorityAcl(Priority, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser
 
getPriorityAcls(String, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getPriorityACLs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getPrivilegedEntity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getPrivilegedEntity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
 
getProcessingChain() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
getProcessorList(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
getProcessorList(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
getProfile(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Get the resource capability associated with given profile name.
getProfile(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
getProgress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptStatusupdateEvent
 
getProgress() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Progress for the application attempt.
getProgress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getProgress() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Progress of application.
getProgress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getProgress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getPromotedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getPromotionRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdates
Returns Container Promotion Requests.
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getProto() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.EpochPBImpl
 
getPUOrderingPolicyUnderUtilizedPreemptionDelay() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
When a reserved container of an underutilized queue is created.
getPUOrderingPolicyUnderUtilizedPreemptionEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Do we allow under-utilized queue with higher priority to preempt queue with lower priority *even if queue with lower priority is not satisfied*.
getPUOrderingPolicyUnderUtilizedPreemptionMoveReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
When doing preemption from under-satisfied queues for priority queue.
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
getQueue() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Each Application is submitted to a queue decided by ApplicationSubmissionContext.setQueue(String).
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Gets a queue by name.
getQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfScheduler
Get queue object based on queue name.
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth.DetailedInformation
 
getQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueueManager
Get a queue matching the specified queue name.
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppQueue
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo.OperationInformation
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
getQueueAcl(String, QueueACL) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
Get the ACLs associated with this queue.
getQueueAcls() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getQueueAcls() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
Get the map of ACLs of all queues.
getQueueACLsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getQueueAction() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
getQueueByPartition(String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getQueueByPartition(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Get queue partition by given queueName and partitionName
getQueueCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueueConfig
 
getQueueCapacities() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get QueueCapacities of this queue
getQueueCapacitiesByPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
getQueueConfigurations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueElements() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Default
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
Applies this rule to an app with the given requested queue and user/group information.
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.NestedUserQueue
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.PrimaryGroup
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Reject
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.SecondaryGroupExistingQueue
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Specified
 
getQueueForApp(String, String, Groups, Map<FSQueueType, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.User
 
getQueueForReservation(ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getQueueForReservation(ReservationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Get the Queue that an existing ReservationId is associated with.
getQueueInfo(GetQueueInfoRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getQueueInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueInfo(String, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getQueueInfo(boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getQueueInfo(boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getQueueInfo(String, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getQueueInfo(boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getQueueInfo(String, boolean, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getQueueInfo(boolean, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get queue information
getQueueInfo(String, boolean, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get queue information
getQueueInfo(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
getQueueInfo(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfoList
 
getQueueInfoList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
getQueueInfoList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfoList
 
getQueueManagementChanges() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.QueueManagementChangeEvent
 
getQueueManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getQueueMappings() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule
 
getQueueMappings() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Get user/group mappings to queues.
getQueueMaxAMShareDefault() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getQueueMaxAMShares() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getQueueMaxApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getQueueMaxAppsDefault() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getQueueMaxResourcesDefault() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getQueueMetrics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Return the QueueMetrics for the queue in the ResourceScheduler corresponding to this plan
getQueueMetrics() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Returns the metrics cache to help prevent re-registrations.
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getQueueName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Return the name of the queue in the ResourceScheduler corresponding to this plan
getQueueName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the queue name.
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getQueueName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get the queue name
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getQueueOrderingPolicy(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getQueueOrderingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getQueuePartitions(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getQueuePartitions(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Get all queue partitions by given queueName
getQueuePath() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueuePath() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the full name of the queue, including the heirarchy.
getQueuePath() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getQueuePlacementManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getQueuePlacementManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getQueuePlacementManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getQueuePlacementPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getQueuePolicies() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getQueuePriority(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getQueueResource(String, Set<String>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
getQueueResourceQuotas() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueResourceQuotas() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get QueueResourceQuotas associated with each queue.
getQueueResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueResourceUsage() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get ResourceUsage of this queue
getQueues(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
getQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.PriorityUtilizationQueueOrderingPolicy
 
getQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a collection of all queues
getQueues() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueueManager
Get all the queues.
getQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getQueues(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getQueueSize() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getQueueState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getQueueStateManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
getQueueStatistics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getQueueStatistics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getQueueUserAclInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getQueueUserAclInfo(UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getQueueUserAclInfo(UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getQueueUserAclInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getQueueUserAclInfo(UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getQueueUserAclInfo(UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
getQueueUserAclInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getQueueUserAclInfo(UserGroupInformation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Get queue ACLs for given user.
getQueueUserAclInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get acls for queues for current user.
getQueueUserAcls(GetQueueUserAclsInfoRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getQueueWeights() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getRack() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getRackCardinality(String, ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Get Rack cardinality for a specific tag.
getRackCardinalityByOp(String, AllocationTags, LongBinaryOperator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Get cardinality for following conditions.
getRackLocalityAdditionalDelay() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getRackLocalityAdditionalDelay() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getRackLocalityDelayMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
getRackLocalityFullReset() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getRackLocalityFullReset() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getRackLocalityThreshold() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getRackName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
The rack name for this node manager.
getRackName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getRackName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get rackname.
getRangeOverlapping(long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
 
getRangeOverlapping(long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Get a RLESparseResourceAllocation view of the Resource allocations between the specified start and end times.
getRanNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Nodes on which the containers for this RMApp ran.
getRanNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getRC() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getReadLock() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getReadLock() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get readLock associated with the Queue.
getRebootedNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getReconnectedNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeReconnectEvent
 
getRecoveredFinalState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getRecoveredFinalState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getRecurrenceExpression() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
getRedirectPath() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
getRejectedRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithmOutput
 
getRelaxLocality() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getReleaseCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getRemainingTimeInSec() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
getRemoteContainerStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerFinishedEvent
 
getRemovedRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeRemovedSchedulerEvent
 
getRenewDate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
getRenewDate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTEvent
 
getRenewDate(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getRenewer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
getReplanner(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getReplanner() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReplanner() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Return an instance of a Planner, which will be invoked in response to unexpected reduction in the resources of this plan
getReplanner(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the name of the Planner class associated with the queue
getReplanner(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getReplanner(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getRequestedPartitions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getRequestLocalityType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getRequestLocalityType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getRequestPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getReReservations(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getReservableNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getReservableNodesRatio() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getReservableQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getReservationAcls(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets a map containing the AccessControlList of users for each ReservationACL acl on thee specified queue.
getReservationAcls(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getReservationAcls() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties
 
getReservationAcls(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getReservationAdmissionPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the name of the SharingPolicy class associated with the queue
getReservationAdmissionPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getReservationAdmissionPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getReservationAdmissionPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getReservationAdmissionPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getReservationAgent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservationAgent() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Return the ReservationAgent configured for this plan that is responsible for optimally placing various reservation requests
getReservationAgent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the name of the ReservationAgent class associated with the queue
getReservationAgent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getReservationAgent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getReservationAgent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getReservationAgent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getReservationAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreStoreReservationEvent
 
getReservationById(ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservationByUserAtTime(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservationContinueLook() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getReservationContinueLooking() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getReservationCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getReservationCountForUserOverTime(String, long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservationDefinition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getReservationDefinition() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the original ReservationDefinition submitted by the client
getReservationDefinition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
getReservationDefinition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
getReservationDefinition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationUpdateRequestInfo
 
getReservationDetails() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getReservationId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the unique identifier ReservationId that represents the reservation
getReservationId() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getReservationID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewReservation
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDeleteRequestInfo
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
getReservationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationUpdateRequestInfo
 
getReservationIdFromQueueName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
getReservationIdFromQueueName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
getReservationIdName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreStoreReservationEvent
 
getReservationName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
getReservationPlanner() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getReservationQueueName(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
getReservationQueueName(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
getReservationQueueResourceIfExists(Plan, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Get reservation queue resources if it exists otherwise return null.
getReservationQueueResourceIfExists(Plan, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
getReservationQueueResourceIfExists(Plan, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
getReservationRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestsInfo
 
getReservationRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
getReservationRequestsInterpreter() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestsInfo
 
getReservations(ReservationId, ReservationInterval) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservations(ReservationId, ReservationInterval, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservationsACLsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getReservationsACLsManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Get the ReservationsACLsManager to use to check for the reservation access on a user.
getReservationsAtTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getReservationSchedulerConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getReservationSchedulerConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getReservationSchedulerConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getReservationState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
getReservationSystem() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getReservationSystem() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getReservationSystem() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getReservationThresholdIncrementMultiple() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getReservationWindow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Gets the length of time in milliseconds for which the SharingPolicy checks for validity
getReservationWindow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getReservationWindow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getReservationWindowMsec() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
getReserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getReserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
getReserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getReserved(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getReserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getReservedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getReservedCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the reserved container in the node.
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Get the list of reserved containers
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppReport
Get the list of reserved containers
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getReservedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getReservedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getReservedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getReservedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getReservedNode() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getReservedNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getReservedNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerReservedEvent
 
getReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getReservedResource() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerReservedEvent
 
getReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getReservedResources(long, Set<ReservationAllocation>, Set<String>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
getReservedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getReservedSchedulerKey() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getReservedSchedulerKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getReservedSchedulerKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerReservedEvent
 
getReservedVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getReservedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getReservedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getReservedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getResolver() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
getResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ConfigurableResource
Get resource by multiplying the cluster resource and the percentage of each resource respectively.
getResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ConfigurableResource
Get the absolute resource.
getResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
getResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
getResourceAllocations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
getResourceByLabel(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
getResourceCalculator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getResourceCalculator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Returns the system ResourceCalculator
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getResourceCalculator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
The ResourceCalculator returned by this method should be used for any calculations involving resources.
getResourceCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getResourceCalculator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
 
getResourceDemandFromAppsPerQueue(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
getResourceInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getResourceLimitForActiveUsers(String, Resource, String, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getResourceLimitForAllUsers(String, Resource, String, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getResourceManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getResourceManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getResourceManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getResourceName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
getResourceOption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeResourceUpdateEvent
 
getResourceOption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeResourceUpdateSchedulerEvent
 
getResourcePreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getResourcePreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getResourcePreemptions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getResourceProfile(GetResourceProfileRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getResourceProfiles(GetAllResourceProfilesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getResourceProfiles() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Get all supported resource profiles.
getResourceProfiles() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
getResourceProfilesManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getResourceProfilesManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getResourceProfilesManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerRequest
 
getResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Get pending ResourceRequests by given schedulerRequestKey
getResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
getResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
getResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerHealthInfo.LastRunDetails
 
getResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
getResourcesAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getResourcesAtTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getResourcesAtTime(long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the capacity represented by cumulative resources reserved by the reservation at the specified point of time
getResourceScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
return the scheduler.
getResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the aggregated number of resources preempted that the application has allocated times the number of seconds the application has been running.
getResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getResourceSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getResourcesInformations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
getResourcesOverTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getResourcesOverTime(long, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getResourcesOverTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Return a RLE representation of used resources.
getResourcesOverTime(long, long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Return a RLE representation of used resources.
getResourcesReleased() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getResourcesReserved() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
getResourcesUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getResourcesUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getResourceToBeAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
getResourceTrackerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
return the resource tracking component.
getResourceTrackerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getResourceTrackerService() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getResourceTrackerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getResourceTypeInfo(GetAllResourceTypeInfoRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getResourceUsage() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Get the aggregate amount of resources consumed by the schedulable.
getResourceUsageInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getResourceUsageReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
Recalculates the per-app, percent of queue metric, specific to the Capacity Scheduler.
getResourceUsageReport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getResourceUsageSecondsMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AggregateAppResourceUsage
 
getResourceUtilization() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getResToObtainByPartitionForLeafQueue(CapacitySchedulerPreemptionContext, String, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionUtils
 
getResult() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppEvent
 
getRetryInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
getRMAdminService() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMAdminService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMAdminService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getRMAppAttempt(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
RMApp can have multiple application attempts RMAppAttempt.
getRMAppAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getRMAppAttemptMetrics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Get metrics from the RMAppAttempt
getRMAppAttemptMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getRMApplicationHistoryWriter() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMApplicationHistoryWriter() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMApplicationHistoryWriter() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getRMAppLifetimeMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getRMAppLifetimeMonitor() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMAppLifetimeMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMAppMetrics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Get RMAppMetrics of the RMApp.
getRMAppMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getRMApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getRMApps() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMBuildVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getRMContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getRMContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.KillableContainer
 
getRmContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
getRMContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getRMContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getRMContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getRMContainer(ContainerId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get the container for the given containerId.
getRMContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getRMContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getRMContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getRMContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getRMContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getRMContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getRMContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getRmContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getRmContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getRMContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
getRMDelegatedNodeLabelsUpdater() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getRMDelegatedNodeLabelsUpdater() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMDelegatedNodeLabelsUpdater() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMDelegationTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getRMDelegationTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMDelegationTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRmDTIdentifier() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTEvent
 
getRMDTSecretManagerState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
getRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeResourceUpdateSchedulerEvent
 
getRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeUpdateSchedulerEvent
 
getRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
getRMNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getRMNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRecoverEvent
 
getRMStateStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getRMStateStoreEventHandler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
getRMStateStoreState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
getRMTimelineCollectorManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMTimelineCollectorManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMTimelineCollectorManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getRMVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getRMVersionBuiltOn() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getRolledLogsExcludePattern() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
getRolledLogsIncludePattern() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
getRoot() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
getRootQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getRootQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
getRootQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getRootQueue() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueueManager
Get the root queue.
getRootQueueInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
 
getRootQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
getRootQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
getRootQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
getRootQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getRootQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getRootQueueMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getRootQueueMetrics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get the root queue for the scheduler.
getRoundedDuration(ReservationRequest, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalByDemand
 
getRpcport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptRegistrationEvent
 
getRpcPort() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The rpc port of the RMAppAttempt.
getRpcPort() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getRules() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementPolicy
 
getRunningApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeReconnectEvent
 
getRunningApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStartedEvent
 
getRunningApps() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getRunningApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
getRunningContainersWithAMsAtTheEnd() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the containers running on the node with AM containers at the end.
getSchedulableEntities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
getSchedulableEntities() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Get the collection of SchedulableEntity Objects which are managed by this OrderingPolicy - should include processes returned by the Assignment and Preemption iterator with no guarantees regarding order.
getScheduleableApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
getScheduleAynschronously() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getScheduler() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
getScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getScheduler() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
getSchedulerApp(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getSchedulerAppInfo(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getSchedulerAppInfo(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get the Scheduler app for a given app attempt Id.
getSchedulerApplicationAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
getSchedulerApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getSchedulerHealth() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getSchedulerHealth() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getSchedulerInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerTypeInfo
 
getSchedulerInfo() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method retrieves the current scheduler status, and it is reachable by using RMWSConsts.SCHEDULER.
getSchedulerInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getSchedulerKeys() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getSchedulerKeys() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getSchedulerNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getSchedulerNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
getSchedulerNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getSchedulerNode(NodeId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get SchedulerNode corresponds to nodeId.
getSchedulerRequestKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
getSchedulerResourceTypes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
getSchedulerType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
getSchedulingEditPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
getSchedulingMode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getSchedulingMode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getSchedulingMonitorManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getSchedulingOpportunities(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Return the number of times the application has been given an opportunity to schedule a task at the given priority since the last time it successfully did so.
getSchedulingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Get the scheduling policy.
getSchedulingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the name of the scheduling policy used by this queue.
getSchedulingRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerRequest
 
getSchedulingRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.PlacedSchedulingRequest
 
getSchedulingRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingRequestWithPlacementAttempt
 
getSchedulingRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingResponse
Get Scheduling Request.
getSchedulingRequests() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithmInput
 
getSchedulingRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Get Collection of SchedulingRequests in this batch.
getSchedulingResourceTypes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Return a collection of the resource types that are considered when scheduling
getSchedulingResourceTypes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
Return a collection of the resource types that are considered when scheduling
getSchedulingResourceTypes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Return a collection of the resource types that are considered when scheduling
getSchedulingResourceTypes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Return a collection of the resource types that are considered when scheduling
getSchedulingResourceUsage() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.SchedulableEntity
View of Resources wanted and consumed by the entity
getSchedulingResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getSecrets() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CredentialsInfo
 
getServer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
getServer(YarnRPC, Configuration, InetSocketAddress, AMRMTokenSecretManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
getServer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
getServer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getServer(YarnRPC, Configuration, InetSocketAddress, AMRMTokenSecretManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
getServer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
getServiceContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
RM service contexts which runs through out JVM life span.
getServices() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.authorize.RMPolicyProvider
 
getServiceStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
Return the HA status of this RM.
getShallowCopyOfPreemptableQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
getSharingPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getSharingPolicy() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Return the configured SharingPolicy that governs the sharing of the resources of the plan between its various users
getShouldFailAutoQueueCreationWhenGuaranteedCapacityExceeded(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Fail further auto leaf queue creation when parent's guaranteed capacity is exceeded.
getShowReservationAsQueues(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Checks whether the reservation queues be hidden or visible
getShowReservationAsQueues(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getShowReservationAsQueues(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getShutdownNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getSignalRequest() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeSignalContainerEvent
 
getSingleNode(CandidateNodeSet<N>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.CandidateNodeSetUtils
 
getSize() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
getSizeBasedWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getSizeBasedWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
getSkippedType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getSource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
getStartedOn() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the start time of the application.
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
Get the start time of the application.
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
getStartTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the time at which the reservation is activated.
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
Get the start time of the reservation interval
getStartTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
the start time of the application.
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getStartTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
the start time of the application.
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getStartTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Start time for jobs in FIFO queues; meaningless for QueueSchedulables.
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the final state of the application attempt.
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
Get the final state of the application.
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The current state of the RMAppAttempt.
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The current state of the RMApp.
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AllocationActivity
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getState(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the current run-state of the queue
getState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueue
Get current queue state.
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppState
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
getStateStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getStateStore() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getStateStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getStateStoreClient() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getStateStoreHeartbeatThread() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getStatItems() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationStatisticsInfo
 
getSteadyFairShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Get the steady fair share assigned to this Schedulable.
getSteadyFairShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the steady fair share of this queue in megabytes.
getSteadyFairShareMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getSteadyFairShareMemoryFraction() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the steady fair share as a fraction of the entire cluster capacity.
getSteadyFairShareVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
getStep() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getStep() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanContext
Returns the configured "step" or granularity of time of the plan in millis.
getStore(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreFactory
 
getStore(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStoreFactory
 
getStrictContainerPreemptions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getSubCluster(GetSubClusterInfoRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getSubClusters(GetSubClustersInfoRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
getSubmissionContext() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The application submission context for this RMAppAttempt.
getSubmissionContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getSubmitTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
The time at which the application was received by the Resource Manager
getSubmitTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getSubmitTime() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
the submit time of the application.
getSubmitTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getSystemCredentialsForApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
getSystemCredentialsForApps() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getSystemCredentialsForApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getSystemMetricsPublisher() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getSystemMetricsPublisher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getSystemMetricsPublisher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getTags() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTags
 
getTargetCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
getTargetQueueForMove() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManagerEvent
 
getTempUserPerPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
getThresholdCalculator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
getThrowOnInvariantViolation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
getTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
getTimeoutType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
getTimePeriod() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Get time period of PeriodicRLESparseResourceAllocation.
getTimeStamp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
getTimestamp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth.DetailedInformation
 
getTimestamp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
getToBePreemptFromOther() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getToBeUpdatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getToBeUpdatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeUpdateContainerEvent
 
getToken() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
getTokenIdentifier() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
getTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CredentialsInfo
 
getTokenState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
getToKillContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
getToPreemptContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getToRelease() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
getTotalAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
getTotalAllocatedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getTotalApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getTotalCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
the total available resource.
getTotalCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getTotalCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getTotalClusterResourcesAcrossPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getTotalCommittedResources(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
getTotalCost() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
getTotalKillableResource(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getTotalKillableResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getTotalMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getTotalNodeCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getTotalNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getTotalPendingRequestsPerPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getTotalPendingResourcesConsideringUserLimit(Resource, String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Get total pending resource considering user limit for the leaf queue.
getTotalReleasedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getTotalReservedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
getTotalResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
getTotalResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get total resources on the node.
getTotalUsedResourcesAcrossPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getTotalVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getTrackingUI() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getTrackingurl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptRegistrationEvent
 
getTrackingUrl() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The url at which the status of the application attempt can be accessed.
getTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getTrackingUrl() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The tracking url for the application master.
getTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getTrackingUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getTrackingUrlPretty() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getTransferredContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
getTransferredContainers(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get previous attempts' live containers for work-preserving AM restart.
getTransferStateFromPreviousAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppStartAttemptEvent
 
getTransferStateFromPreviousAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppFailedAttemptEvent
 
getTransferStateFromPreviousAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAttemptAddedSchedulerEvent
 
getTransitionToQueueState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
getType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
getType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
getType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
getType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
getTypeToTagsWithCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager.TypeToCountedTags
 
getUnallocatedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get unallocated resources on the node.
getUnderServedQueuesPerPartition(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
getUnderServedQueuesPerPartition(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getUnhealthyNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getUnhealthyNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getUniqueLocationAsks() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
 
getUniqueLocationAsks() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
getUniqueLocationAsks() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
getUnits(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getUnmanagedAM() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getUnmanagedAM() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
getUntrackedTimeStamp() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getUntrackedTimeStamp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getUpdateContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getUpdateContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getUpdatedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
getUpdatedNodeToLabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeLabelsUpdateSchedulerEvent
 
getUpdatedQueueTemplate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
getUpdateInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getUpdateType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent
 
getUrl() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
getUsageRatio(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
getUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage.UsageByLabel
 
getUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getUsed(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getUsed(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getUsed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getUsedAMResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUsedAMResourceMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getUsedAMResourceVCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getUsedCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the current used capacity of nodes without label(s) of the queue and it's children (if any).
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getUsedCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
getUsedDeductAM() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
getUsedMemory() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getUsedMemoryFraction() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the memory used by this queue as a fraction of the entire cluster capacity.
getUsedMemoryOpportGB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getUsedNodeCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNodeReport
 
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getUsedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getUsedResources() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the currently utilized resources which allocated at nodes without any labels in the cluster by the queue and children (if any).
getUsedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeReport
 
getUsedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getUsedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getUsedVirtualCoresOpport() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getUsePortForNodeName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getUsePortForNodeName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
getUser() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Returns the user who requested the reservation
getUser() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
The user who submitted this application.
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Get user object for given user name.
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
getUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
getUserAMLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getUserAMLimit(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
getUserAmLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
getUserAMResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUserAMResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUserAMResourceLimitPerPartition(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUserAndAddIfAbsent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Get and add user if absent.
getUserGroupMappingPlacementRule() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getUserLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
getUserLimit(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getUserLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUserLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Get configured user-limit.
getUserLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUserLimitFactor(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getUserLimitFactor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUserLimitFactor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
User limit factor value for each of the reservations in this Plan.
getUserLimitFactor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Get configured user-limit factor.
getUserLimitFactor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUserLimitForReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
User limit value for each of the reservations in this Plan.
getUserMaxApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getUserMaxApps(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
getUserMaxAppsDefault() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
getUserMetrics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
getUserMetrics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getUserName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
getUsername() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getUserName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getUserResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getUserResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
getUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUsersInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
getUsersList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UsersInfo
 
getUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUsersPerPartition() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
getUserWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getUserWeights() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
getUserWeights() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get a map of usernames and weights
getValidSourceTag(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManagerService
This method will return a single allocation tag.
getValidWindow() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityOverTimePolicy
 
getValidWindow() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.NoOverCommitPolicy
 
getValidWindow() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.SharingPolicy
Returns the time range before and after the current reservation considered by this policy.
getvCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
getVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Get the vcore seconds of the application.
getVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
getVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AggregateAppResourceUsage
 
getVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
getVcoreSeconds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getVcoresPerNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
getVersion() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.CandidateNodeSet
Version of the CandidateNodeSet, can help AppPlacementAllocator to decide if update is required
getVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SimpleCandidateNodeSet
 
getVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
getVisibility() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
getWaitTimeBeforeKill() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getWaitTimeBeforeNextStarvationCheck() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getWebAppFilterClass() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
getWebProxyBase() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
The base to be prepended to web URLs that are not relative, and the user has been checked.
getWebProxyBase() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
getWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
getWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
getWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getWeight() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Job/queue weight in fair sharing.
getWriteLock() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getWriteLock() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
getYarnConfiguration() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getYarnConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getYarnConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
getYarnRPC() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
getZKManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getZkRootNodePassword() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getZookeeperConnectionState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
getZookeeperConnectionState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
getZookeeperConnectionState() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.EmbeddedElector
Get information about the elector's connection to Zookeeper.
GreedyReservationAgent - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
This Agent employs a simple greedy placement strategy, placing the various stages of a ReservationDefinition from the deadline moving backward towards the arrival.
GreedyReservationAgent() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.GreedyReservationAgent
 
GuaranteedOrZeroCapacityOverTimePolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement
Capacity Management policy for auto created leaf queues
GuaranteedOrZeroCapacityOverTimePolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 

H

hadoopBuildVersion - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
hadoopVersion - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
hadoopVersionBuiltOn - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
handle(AMLauncherEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
handle(NodesListManagerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
handle(SchedulerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
handle(RMAppAttemptEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.ApplicationAttemptEventDispatcher
 
handle(RMAppEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.ApplicationEventDispatcher
 
handle(RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.NodeEventDispatcher
 
handle(RMAppAttemptEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
handle(RMAppEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
handle(RMAppManagerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
handle(RMContainerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
handle(RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
handle(SchedulerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
handle(SchedulerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
handle(SchedulerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
handleContainerUpdates(SchedulerApplicationAttempt, ContainerUpdates) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
handleStoreEvent(RMStateStoreEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
handleWritingApplicationHistoryEvent(WritingApplicationHistoryEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
hasAccess(QueueACL, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
hasAccess(QueueACL, UserGroupInformation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Check if the user has permission to perform the operation
hasAccess(QueueACL, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
hasAccess(QueueACL, UserGroupInformation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
 
hasAccess(RMApp, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
hasApplicationMasterRegistered(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
hasChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
hasChildQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptFinishEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptStartEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationFinishEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationStartEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerFinishEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerStartEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.TimelinePublishEvent
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppToMonitor
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
hasMasterKey(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
hasNext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner.StageProvider
 
hasNext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators.PopularTagsIterator
 
hasNext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators.SerialIterator
 
hasParentQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.ApplicationPlacementContext
 
hasParentQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
hasPendingApps(AutoCreatedLeafQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
hasPendingResourceRequest(ResourceCalculator, String, Resource, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
hasPendingResourceRequest(ResourceCalculator, ResourceUsage, String, Resource, SchedulingMode) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
haState - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
hasUpdateThreadRunChanged() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSOpDurations
 
haZooKeeperConnectionState - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
HDFS_DELEGATION_KIND - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
health - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
healthReport - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
httpServerTemplateForRM(Configuration, InetSocketAddress, InetSocketAddress, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Return a HttpServer.Builder that the journalnode / namenode / secondary namenode can use to initialize their HTTP / HTTPS server.

I

id - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
id - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
id - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
immutableCopy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager.TypeToCountedTags
 
incAMLimit(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incAMLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incAMUsed(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
incAMUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incAMUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incAMUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
INCLUDE_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
incNumAllocatedContainers(NodeType, NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
incNumAllocatedContainers(NodeType, NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
incPending(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incPending(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incPendingResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
incPendingResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
incPendingResource(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
When new outstanding resource is asked, calling this will increase pending resource in a queue.
incrActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
incrAllocations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
incrAllocations(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
incrDecommisionedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrDecommissioningNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incReserved(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incReserved(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incReservedResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
incReservedResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
incReservedResource(String, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Increment Reserved Capacity
incrNodeTypeAggregations(String, NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
incrNumActiveNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrNumLostNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrNumRebootedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrNumShutdownNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrNumUnhealthyNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrPendingResources(String, String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Increment pending resource metrics
incrReservations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
incrReservations(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation
 
incUnconfirmedRes(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
incUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
incUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
incUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
When partition of node updated, we will update queue's resource usage if it has container(s) running on that.
incUsedResource(String, Resource, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
incUsedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Increase resource usage for this queue and all parent queues.
index() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getClusterInfo.
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher
 
init(Configuration, RMContext, ResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
init(Configuration, RMContext, ResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
init(Configuration, RMContext, ResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.MetricsInvariantChecker
 
init(Configuration, RMContext, ResourceScheduler) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
 
init(Clock, ResourceScheduler, Collection<Plan>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
init(String, ReservationSchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityOverTimePolicy
 
init(Clock, ResourceScheduler, Collection<Plan>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacitySchedulerPlanFollower
 
init(Clock, ResourceScheduler, Collection<Plan>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairSchedulerPlanFollower
 
init(String, ReservationSchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.NoOverCommitPolicy
 
init(Clock, ResourceScheduler, Collection<Plan>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanFollower
Init function that configures the PlanFollower, by providing:
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.GreedyReservationAgent
 
init(String, ReservationSchedulerConfiguration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.Planner
Initialize the replanner
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
init(Configuration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.ReservationAgent
Init configuration.
init(String, ReservationSchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.SimpleCapacityReplanner
 
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.TryManyReservationAgents
 
init(String, ReservationSchedulerConfiguration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.SharingPolicy
Initialize this policy.
init(Configuration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Method to handle all initialization steps for ResourceProfilesManager.
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
init(CapacitySchedulerContext, ParentQueue) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedQueueManagementPolicy
Initialize policy
init(Configuration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.CSConfigurationProvider
Initialize the configuration provider with given conf.
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.FileBasedCSConfigurationProvider
 
init(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
init(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.QueueAdminConfigurationMutationACLPolicy
 
init(CapacitySchedulerContext, ParentQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
init(Configuration, RMContext, ResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
init(Configuration, RMContext) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ConfigurationMutationACLPolicy
Initialize ACL policy with configuration and RMContext.
init(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.DefaultPlacementAlgorithm
 
init(RMContext) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithm
Initialize the Algorithm.
init(ApplicationMasterServiceContext, ApplicationMasterServiceProcessor) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.AbstractPlacementProcessor
 
init(ApplicationMasterServiceContext, ApplicationMasterServiceProcessor) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.PlacementConstraintProcessor
 
init(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.DefaultConfigurationMutationACLPolicy
 
initAppsTable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
initAppsTable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
initFields(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields
Initial DeSelectFields with unselected fields.
initFSQueue(FSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
Initialize a FSQueue with queue-specific properties and its metrics.
initialize(RMContext, Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
initialize(Map<String, String>, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule
 
initialize(Plan, ReservationId, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
initialize(Configuration, Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
initialize(Configuration, Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
initialize(Configuration, Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Initialize the configuration store, with schedConf as the initial scheduler configuration.
initialize(Configuration, Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
initialize(FSContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
initialize(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
initialize(boolean, Map<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Default
 
initialize(boolean, Map<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
Initializes the rule with any arguments.
initialize(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Deprecated.
Since it doesn't track cluster resource changes, replaced by SchedulingPolicy.initialize(FSContext).
initialize(FSContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Initialize the scheduling policy with a FSContext object, which has a pointer to the cluster resources among other information.
initialize(AppSchedulingInfo, SchedulerRequestKey, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Initialize this allocator, this will be called by Factory automatically.
initialize(AppSchedulingInfo, SchedulerRequestKey, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
initialize(SchedulerQueueManager<T, E>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueStateManager
 
initializeFromXml(Element) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Default
 
initializeFromXml(Element) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
 
initializeFromXml(Element) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.NestedUserQueue
Parse xml and instantiate the nested rule
initializeLeafQueueConfigs(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
initializeLeafQueueConfigs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
initializePlan(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
initializeQueues(CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
Initialized the queues.
initializeRootIdealWithGuarangeed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
This method is visible to allow sub-classes to ovverride the behavior, specifically for federation purposes we need to initialize per-sub-cluster roots as well as the global one.
initIdealAssignment(Resource, TempQueuePerPartition, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptableResourceCalculator
This method is visible to allow sub-classes to override the initialization behavior.
initInternal(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
initInternal(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
initInternal(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
initInternal(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
initInternal(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived classes initialize themselves using this method.
initInternal(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
initMaximumResourceCapability(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
initThresholdCalculator(float, int, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
InMemoryConfigurationStore - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
A default implementation of YarnConfigurationStore.
InMemoryConfigurationStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
InMemoryPlan - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This class represents an in memory representation of the state of our reservation system, and provides accelerated access to both individual reservations and aggregate utilization of resources over time.
InMemoryPlan(QueueMetrics, SharingPolicy, ReservationAgent, Resource, long, ResourceCalculator, Resource, Resource, String, Planner, boolean, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
InMemoryPlan(QueueMetrics, SharingPolicy, ReservationAgent, Resource, long, ResourceCalculator, Resource, Resource, String, Planner, boolean, long, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
InMemoryPlan(QueueMetrics, SharingPolicy, ReservationAgent, Resource, long, ResourceCalculator, Resource, Resource, String, Planner, boolean, long, RMContext, Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
InMemoryReservationAllocation - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
An in memory implementation of a reservation allocation using the RLESparseResourceAllocation
InMemoryReservationAllocation(ReservationId, ReservationDefinition, String, String, long, long, Map<ReservationInterval, Resource>, ResourceCalculator, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
InMemoryReservationAllocation(ReservationId, ReservationDefinition, String, String, long, long, Map<ReservationInterval, Resource>, ResourceCalculator, Resource, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
INSTANTANEOUS_MAX_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
INTRAQUEUE_PREEMPTION_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
For intra-queue preemption, priority/user-limit/fairness based selectors can help to preempt containers.
INTRAQUEUE_PREEMPTION_MAX_ALLOWABLE_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
For intra-queue preemption, allowable maximum-preemptable limit per queue.
INTRAQUEUE_PREEMPTION_MINIMUM_THRESHOLD - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
For intra-queue preemption, consider those queues which are above used cap limit.
INTRAQUEUE_PREEMPTION_ORDER_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
For intra-queue preemption, enforce a preemption order such as "userlimit_first" or "priority_first".
IntraQueueCandidatesSelector - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Identifies over utilized resources within a queue and tries to normalize them to resolve resource allocation anomalies w.r.t priority and user-limit.
intraQueuePreemptionDisabled - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
INVALID_FAIR_SHARE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
 
InvalidAllocationTagsQueryException - Exception in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Exception when invalid parameter specified to do placement tags related queries.
InvalidAllocationTagsQueryException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.InvalidAllocationTagsQueryException
 
InvalidAllocationTagsQueryException(YarnException) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.InvalidAllocationTagsQueryException
 
InvalidQueueNameException - Exception in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Thrown when Queue Name is malformed.
InvalidQueueNameException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.InvalidQueueNameException
 
InvalidQueueNameException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.InvalidQueueNameException
 
INVARIANT_MONITOR_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
INVARIANTS_FILE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.MetricsInvariantChecker
 
InvariantsChecker - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants
Abstract invariant checker, that setup common context for invariants checkers.
InvariantsChecker() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
InvariantViolationException - Exception in org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants
This exception represents the violation of an internal invariant.
InvariantViolationException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantViolationException
 
InvariantViolationException(String, Exception) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantViolationException
 
invokePolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
IS_RESERVABLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
isAclDefinedForAccessType(String, AccessType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
isActive(AutoCreatedLeafQueue, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
isActive() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Returns true if queue has at least one app running.
isAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
isAllocateLeft() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.GreedyReservationAgent
 
isAllowed() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
isAllowPreemption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
isAMContainer() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
isAMContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
isAmRunning() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
isAppFinalStateStored() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Check whether this application's state has been saved to the state store.
isAppFinalStateStored() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
isAppInCompletedStates() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
To verify whether app has reached in its completing/completed states.
isAppInCompletedStates() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
isAppInFinalState(RMApp) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
isApplicationAttemptNMTokenPresent(ApplicationAttemptId, NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
isApplicationAttemptRegistered(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
isAtLeastReservationThreshold(ResourceCalculator, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
isAutoCreateChildQueueEnabled(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
If true, this queue will be created as a Parent Queue which Auto Created leaf child queues
isAutoCreatedLeafQueue - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
isAutoCreatedLeafQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
isChildPolicyAllowed(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
isChildPolicyAllowed(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
isChildPolicyAllowed(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Check whether the policy of a child queue is allowed.
isConfigurationMutable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
isConfigurationMutable() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
Returns if configuration is mutable.
isConfigurationMutable() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfScheduler
Return whether the scheduler configuration is mutable.
isContainerAlreadySelected(RMContainer, Map<ApplicationAttemptId, Set<RMContainer>>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionUtils
 
isContinuousSchedulingEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
Continuous scheduling should not be turned ON. It is deprecated because it can cause scheduler slowness due to locking issues. Schedulers should use assignmultiple as a replacement.
isContinuousSchedulingEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
use FairSchedulerConfiguration.ASSIGN_MULTIPLE to improve container allocation ramp up.
isEmpty() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Returns true if there are no non-zero entries.
isEmpty(FSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Returns true if there are no applications, running or not, in the given queue or any of its descendents.
isFencedState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
isFulfilledReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
isHAEnabled() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
isHAEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
isHAEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
isIncrease() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
isIncrease() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerExpiredSchedulerEvent
 
isIncreasedAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
isIncreasedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerUpdatesAcquiredEvent
 
isLeader() - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
isLeafQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
isMaxAssignDynamic() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
isMutationAllowed(UserGroupInformation, SchedConfUpdateInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.QueueAdminConfigurationMutationACLPolicy
 
isMutationAllowed(UserGroupInformation, SchedConfUpdateInfo) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ConfigurationMutationACLPolicy
Check if mutation is allowed.
isMutationAllowed(UserGroupInformation, SchedConfUpdateInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.DefaultConfigurationMutationACLPolicy
 
isNotifyApplication() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppEvent
 
isObserveOnly() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionContext
 
isObserveOnly() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
isOverlap(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
Returns whether the interval is active at the specified instant of time
isPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
isPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Is this application pending?
isPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppReport
Is this application pending?
isPlaceBlacklisted(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
Returns if the place (node/rack today) is either blacklisted by the application (user) or the system.
isPlaceBlacklisted(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
isPlaceBlacklisted(SchedulerApplicationAttempt, SchedulerNode, Log) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppUtils
 
isPreemptable(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
isPreemptable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
isPreemptable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
isPreemptable() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Check whether the schedulable is preemptable.
isPreemptable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
isPreemptionQuotaForULDeltaDone() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
isRecovering() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.SchedulableEntity
Whether application was running before RM restart.
isRecovering() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
isRemotelyAllocated() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
If the container was allocated by a container other than the Resource Manager (e.g., the distributed scheduler in the NM LocalScheduler).
isRemotelyAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
isReservable(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
Checks if the queue participates in reservation based scheduling
isReservable(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
isReservable(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
isReservedPreemptionCandidatesSelector - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptableResourceCalculator
 
isRSMEmpty() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
isSameConfiguredPolicies(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
isSchedulerReadyForAllocatingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
isSchedulerReadyForAllocatingContainers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
isSchedulerReadyForAllocatingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
isSizeBasedWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
isStandby() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
isStopped - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
isStopped() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
isSuccess() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingResponse
Returns true if Scheduler was able to accept and commit this request.
isSystemAppsLimitReached() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Default
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
Returns true if this rule never tells the policy to continue.
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.NestedUserQueue
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.PrimaryGroup
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Reject
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.SecondaryGroupExistingQueue
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Specified
 
isTerminal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.User
 
isTimerCancelled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
isTrackingUrlReady() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
isUnmanagedApp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
isUntrackedNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
isUpdate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAMRMTokenEvent
 
isUserLimitReached(ResourceCalculator, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
isValidContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Check if a container is launched by this node.
isValidNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
isWaitingForAMContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
isWorkPreservingRecoveryEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
isWorkPreservingRecoveryEnabled() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
isWorkPreservingRecoveryEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
IterativePlanner - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
A planning algorithm consisting of two main phases.
IterativePlanner(StageExecutionInterval, StageAllocator, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
IterativePlanner.StageProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
Helper class that provide a list of ReservationRequests and iterates forward or backward depending whether we are allocating left-to-right or right-to-left.
iterator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests
Exposes SchedulingRequest Iterator interface which can be used to traverse requests using different heuristics i.e.

J

JAXBContextResolver - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
JAXBContextResolver() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.JAXBContextResolver
 

K

KILL_APP_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
KillableContainer - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption
 
KillableContainer(RMContainer, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.KillableContainer
 
killAllAppsInQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
killAllAppsInQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Terminate all applications in the specified queue.
killApp(RMApp, UserGroupInformation, HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
killContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Kill a RMContainer.
killContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
killContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
killContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
killReservedContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
killReservedContainer(RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.PreemptableResourceScheduler
If the scheduler support container reservations, this method is used to ask the scheduler to drop the reservation for the given container.

L

LABEL_MAPPINGS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getLabelsToNodes.
LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
labelsToNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LabelsToNodesInfo
 
LabelsToNodesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
LabelsToNodesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LabelsToNodesInfo
 
LabelsToNodesInfo(Map<NodeLabelInfo, NodeIDsInfo>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LabelsToNodesInfo
 
LAST_NODE_PROCESSED_MSG - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
lastMemoryAggregateAllocationUpdateTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
lastNodeUpdateTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
lastScheduledContainer - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
LAZY_PREEMPTION_ENABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
LeafQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
LeafQueue(CapacitySchedulerContext, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
LeafQueue(CapacitySchedulerContext, CapacitySchedulerConfiguration, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
leafQueueTemplate - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
LeveldbConfigurationStore - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
A LevelDB implementation of YarnConfigurationStore.
LeveldbConfigurationStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
LeveldbRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
Changes from 1.0 to 1.1, Addition of ReservationSystem state.
LeveldbRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
LIST_RESERVATION_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
listReservation(String, String, long, long, boolean, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Function to retrieve a list of all the reservations.
listReservation(String, String, long, long, boolean, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
listReservations(ReservationListRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
liveContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
loadConfiguration(Configuration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.CSConfigurationProvider
Loads capacity scheduler configuration object.
loadConfiguration(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.FileBasedCSConfigurationProvider
 
loadConfiguration(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
loadDynamicResourceConfiguration(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
Load DynamicResourceConfiguration from dynamic-resources.xml.
loadNewConfiguration() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API The derived class must recover state from the store and return a new RMState object populated with that state This must not be called on the dispatcher thread
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
loadUpdateAndCheckCapacities(String, CapacitySchedulerConfiguration, QueueCapacities, QueueCapacities) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
Do following steps for capacities - Load capacities from configuration - Update absolute capacities for new capacities - Check if capacities/absolute-capacities legal
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived class use this method to load the version information from state store.
loadVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
LOCALITY_DELAY_NODE_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
Continuous scheduling is known to cause locking issue inside Only used when FairSchedulerConfiguration.CONTINUOUS_SCHEDULING_ENABLED is enabled
LOCALITY_DELAY_RACK_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
Continuous scheduling is known to cause locking issue inside Only used when FairSchedulerConfiguration.CONTINUOUS_SCHEDULING_ENABLED is enabled
LOCALITY_SKIPPED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
LOCALITY_SKIPPED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
Skip the locality (e.g.
LOCALITY_THRESHOLD_NODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Cluster threshold for node locality.
LOCALITY_THRESHOLD_RACK - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Cluster threshold for rack locality.
LocalityAppPlacementAllocator<N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
This is an implementation of the AppPlacementAllocator that takes into account locality preferences (node, rack, any) when allocating containers.
LocalityAppPlacementAllocator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
LocalResourceInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
LocalResourceInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreUtils
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManagerService
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
LOG - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
 
LogAggregationContextInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class to allow users to send information required to create a ContainerLaunchContext which can then be used as part of the ApplicationSubmissionContext
LogAggregationContextInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
logAggregationStatus - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
logaggregationstatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
logAndApplyMutation(UserGroupInformation, SchedConfUpdateInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
logAndApplyMutation(UserGroupInformation, SchedConfUpdateInfo) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfigurationProvider
Log user's requested configuration mutation, and applies it in-memory.
logApplicationSummary(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
logFailure(String, String, String, String, String, ApplicationId, ContainerId, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a failed event.
logFailure(String, String, String, String, String, ApplicationId, ApplicationAttemptId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a failed event.
logFailure(String, String, String, String, String, ApplicationId, CallerContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
 
logFailure(String, String, String, String, String, ApplicationId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a failed event.
logFailure(String, String, String, String, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a failed event.
logFailure(String, String, String, String, String, RMAuditLogger.ArgsBuilder) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a failed event.
logMutation(YarnConfigurationStore.LogMutation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
logMutation(YarnConfigurationStore.LogMutation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
logMutation(YarnConfigurationStore.LogMutation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Logs the configuration change to backing store.
logMutation(YarnConfigurationStore.LogMutation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
logOrThrow(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
logsLink - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
logSuccess(String, String, String, ApplicationId, ContainerId, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a successful event.
logSuccess(String, String, String, RMAuditLogger.ArgsBuilder) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a general readable and parseable audit log string for a successful event.
logSuccess(String, String, String, InetAddress, RMAuditLogger.ArgsBuilder) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a general readable and parseable audit log string for a successful event.
logSuccess(String, String, String, ApplicationId, ApplicationAttemptId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a successful event.
logSuccess(String, String, String, ApplicationId, CallerContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
 
logSuccess(String, String, String, ApplicationId, InetAddress) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a successful event.
logSuccess(String, String, String, ApplicationId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a successful event.
logSuccess(String, String, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
Create a readable and parseable audit log string for a successful event.
LOST_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 

M

main(String[]) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ManagedParentQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Auto Creation enabled Parent queue.
ManagedParentQueue(CapacitySchedulerContext, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
markContainerForKillable(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
markContainerForKillable(RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.PreemptableResourceScheduler
Ask the scheduler to forcibly interrupt the container given as input
markContainerForPreemption(ApplicationAttemptId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
markContainerForPreemption(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
markContainerForPreemption(ApplicationAttemptId, RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.PreemptableResourceScheduler
Ask the scheduler to obtain back the container from a specific application by issuing a preemption request
markContainerToKillable(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
markContainerToNonKillable(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
masterService - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
masterServiceAddress - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
matchContainerToOutstandingIncreaseReq(SchedulerNode, SchedulerRequestKey, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
Check if a new container is to be matched up against an outstanding Container increase request.
MAX_ASSIGN - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Specify exact number of containers to assign on each heartbeat, if dynamic max assign is turned off.
MAX_ASSIGN_PER_HEARTBEAT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Maximum number of containers to assign on each check-in.
MAX_TIME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
MAX_WAIT_BEFORE_KILL_FOR_QUEUE_BALANCE_PREEMPTION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
How long we will wait to balance queues, by default it is 5 mins.
maxAllocResource - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
maxAMShare - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
maxApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
maxApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
maxApplicationsPerUser - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
maxApplicationsPerUser - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
maxAssign - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
maxCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
maxCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
maxChildQueueResources(String, ConfigurableResource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
maxDate - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
maxEffectiveCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
MAXIMUM_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_AM_RESOURCE_SUFFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_APPLICATION_MASTERS_RESOURCE_PERCENT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_APPLICATIONS_SUFFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_CAPACITY_VALUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_LIFETIME_SUFFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_PROFILE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
MAXIMUM_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MAXIMUM_SYSTEM_APPLICATIONS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
maximumClusterPriority - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
maxQueueMemoryCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
maxQueueResources(String, ConfigurableResource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
maxRunningApps - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
MaxRunningAppsEnforcer - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Handles tracking and enforcement for user and queue maxRunningApps constraints
MaxRunningAppsEnforcer(FairScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
 
MEMORY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
MemoryPlacementConstraintManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
In memory implementation of the PlacementConstraintManagerService.
MemoryPlacementConstraintManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
MemoryRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
MemoryRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
merge(ResourceCalculator, Resource, RLESparseResourceAllocation, RLESparseResourceAllocation, RLESparseResourceAllocation.RLEOperator, long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Merges the range start to end of two RLESparseResourceAllocation using a given RLEOperator.
METRICS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getClusterMetricsInfo.
metricsAvailable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
MetricsInvariantChecker - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants
This policy checks at every invocation that a given set of invariants (specified in a file) are respected over QueueMetrics and JvmMetrics.
MetricsInvariantChecker() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.MetricsInvariantChecker
 
MetricsOverviewTable - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
Provides an table with an overview of many cluster wide metrics and if per user metrics are enabled it will show an overview of what the current user is using on the cluster.
metricsSystem - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
minAllocResource - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
minEffectiveCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
MINIMUM_CAPACITY_VALUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
MINIMUM_PROFILE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
MINIMUM_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Configuring absolute min/max resources in a queue.
minimumAllocation - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
minQueueMemoryCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
minQueueResources(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
minShare - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
minSharePreemptionTimeouts(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
monitorHealth() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
move(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
move(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
MOVE_APP_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
moveAllApps(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
moveAllApps(String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Completely drain sourceQueue of applications, by moving all of them to destQueue.
moveApp(RMApp, UserGroupInformation, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
moveAppFrom(AppSchedulingInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
moveApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
moveApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
moveApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
moveApplication(ApplicationId, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Moves the given application to the given queue
moveApplicationAcrossQueue(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
moveToQueue will invoke scheduler api to perform move queue operation.
moveApplicationAcrossQueues(MoveApplicationAcrossQueuesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
moveAppTo(AppSchedulingInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
moveKillableContainer(KillableContainer, KillableContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
moveReservation(RMContainer, FiCaSchedulerNode, FiCaSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
Move reservation from one node to another Comparing to unreserve container on source node and reserve a new container on target node.
moveReservedContainer(RMContainer, FiCaSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
Try to move a reserved container to a targetNode.
MultiThreadedDispatcher(int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter.MultiThreadedDispatcher
 
MultiThreadedDispatcher(int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.MultiThreadedDispatcher
 
MutableConfigurationProvider - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Interface for allowing changing scheduler configurations.
MutableConfScheduler - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Interface for a scheduler that supports changing configuration at runtime.
MutableCSConfigurationProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
CS configuration provider which implements MutableConfigurationProvider for modifying capacity scheduler configuration.
MutableCSConfigurationProvider(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 

N

NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
name - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivityNodeInfo
 
NAMESPACE_DELIMITER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
 
nav() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
NavBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
NavBlock() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.NavBlock
 
NestedUserQueue() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.NestedUserQueue
 
NewApplication - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NewApplication() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewApplication
 
NewApplication(String, ResourceInfo) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewApplication
 
newInstance(MasterKey, MasterKey) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
 
newInstance(AMRMTokenSecretManagerState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
 
newInstance(ApplicationAttemptId, Container, Credentials, long, RMAppAttemptState, String, String, FinalApplicationStatus, int, long, Map<String, Long>, Map<String, Long>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
newInstance(ApplicationAttemptId, Container, Credentials, long, Map<String, Long>, Map<String, Long>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
newInstance(long, long, String, ApplicationSubmissionContext, RMAppState, String, long, CallerContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
newInstance(long, long, String, ApplicationSubmissionContext, RMAppState, String, long, CallerContext, Map<ApplicationTimeoutType, Long>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
newInstance(long, long, ApplicationSubmissionContext, String, CallerContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
newInstance(long, long, ApplicationSubmissionContext, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
newInstance(long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
newlyAllocatedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
newlyDecreasedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
newlyDemotedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
newlyIncreasedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
newlyPromotedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
NewReservation - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
The response sent by the ResourceManager to the client for a request to get a new ReservationId for submitting reservations using the REST API.
NewReservation() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewReservation
 
NewReservation(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NewReservation
 
next() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner.StageProvider
 
next() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators.PopularTagsIterator
 
next() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators.SerialIterator
 
nextAMSProcessor - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.AbstractPlacementProcessor
 
nmExpireInterval - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
nmHeartbeatInterval - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
NMLivelinessMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager
 
NMLivelinessMonitor(Dispatcher) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.NMLivelinessMonitor
 
nmLivelinessMonitor - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
NMTokenSecretManagerInRM - Class in org.apache.hadoop.yarn.server.resourcemanager.security
 
NMTokenSecretManagerInRM(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
NODE() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.NODE
 
node - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodesInfo
 
NODE_LOCALITY_DELAY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
NodeAddedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
NodeAddedSchedulerEvent(RMNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeAddedSchedulerEvent
 
NodeAddedSchedulerEvent(RMNode, List<NMContainerStatus>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeAddedSchedulerEvent
 
NodeAllocation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
NodeAllocation(NodeId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
NodeAllocationInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeCandidateSelector - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
A read only implementation of the ClusterNodeTracker which exposes a method to simply return a filtered list of nodes.
nodeCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
nodeCount(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
nodeCPUUsage - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
NodeEventDispatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.NodeEventDispatcher
 
NodeFilter - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Convenience way to filter nodes based on a criteria.
nodeHeartbeat(NodeHeartbeatRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
nodeHostName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
nodeHttpAddress - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
nodeHTTPAddress - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
nodeId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
nodeId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
nodeId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
NODEID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
NodeIDsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
XML element uses to represent NodeIds' list.
NodeIDsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeIDsInfo
 
NodeIDsInfo(List<String>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeIDsInfo
 
nodeIDsList - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeIDsInfo
Set doesn't support default no arg constructor which is req by JAXB
NodeInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
NodeInfo(RMNode, ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
NodeLabelInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeLabelInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
NodeLabelInfo(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
NodeLabelInfo(String, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
NodeLabelInfo(NodeLabel) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelInfo
 
nodeLabels - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
nodeLabels - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
nodelabels() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
NodeLabelsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeLabelsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
NodeLabelsInfo(ArrayList<NodeLabelInfo>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
NodeLabelsInfo(List<NodeLabel>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
NodeLabelsInfo(Set<String>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
NodeLabelsPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
NodeLabelsPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeLabelsPage
 
nodeLabelsUpdateInterval - Variable in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
 
NodeLabelsUpdateSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
NodeLabelsUpdateSchedulerEvent(Map<NodeId, Set<String>>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeLabelsUpdateSchedulerEvent
 
NodeLabelsUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.nodelabels
Node labels utilities.
nodeLocalityDelayMs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
nodeLocalityThreshold - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
nodePartitionUpdated(RMContainer, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
nodePhysicalMemoryMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
NodeQueueLoadMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed
The NodeQueueLoadMonitor keeps track of load metrics (such as queue length and total wait time) associated with Container Queues on the Node Manager.
NodeQueueLoadMonitor(long, NodeQueueLoadMonitor.LoadComparator) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
NodeQueueLoadMonitor.LoadComparator - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed
The comparator used to specify the metric against which the load of two Nodes are compared.
NodeRemovedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
NodeRemovedSchedulerEvent(RMNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeRemovedSchedulerEvent
 
NodeReport - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Node usage report.
NodeReport(Resource, int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeReport
 
NodeResourceUpdateSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
NodeResourceUpdateSchedulerEvent(RMNode, ResourceOption) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeResourceUpdateSchedulerEvent
 
NodeResponse - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
The class that encapsulates response from clusterinfo for updates from the node managers.
NodeResponse(List<ApplicationId>, List<Container>, List<Container>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeResponse
 
NODES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
nodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
NODES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getNodes.
NODES_NODEID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getNode.
NODES_NODEID_GETLABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getLabelsOnNode.
NODES_NODEID_REPLACE_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#replaceLabelsOnNode.
NodesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodesInfo
 
NodesListManager - Class in org.apache.hadoop.yarn.server.resourcemanager
 
NodesListManager(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
nodesListManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
NodesListManager.CachedResolver - Class in org.apache.hadoop.yarn.server.resourcemanager
 
NodesListManager.DirectResolver - Class in org.apache.hadoop.yarn.server.resourcemanager
 
NodesListManager.Resolver - Interface in org.apache.hadoop.yarn.server.resourcemanager
 
NodesListManagerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager
 
NodesListManagerEvent(NodesListManagerEventType, RMNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.NodesListManagerEvent
 
NodesListManagerEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager
 
nodeToLabels - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntryList
 
NodeToLabelsEntry - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeToLabelsEntry() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntry
 
NodeToLabelsEntry(String, ArrayList<String>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntry
 
NodeToLabelsEntryList - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeToLabelsEntryList() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsEntryList
 
NodeToLabelsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
NodeToLabelsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeToLabelsInfo
 
nodeTracker - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
NodeType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Resource classification.
nodeUpdate(RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Process a heartbeat update from a node.
nodeUpdate(RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
nodeUpdate(RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
nodeUpdate(RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
NodeUpdateSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
NodeUpdateSchedulerEvent(RMNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeUpdateSchedulerEvent
 
nodeVirtualMemoryMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
NON_PARTITIONED_PARTITION_FIRST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
NONE_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser
 
NONE_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
nonPreemptableQueues(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
NoOpSystemMetricPublisher - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
This class does nothing when any of the methods are invoked on SystemMetricsPublisher.
NoOpSystemMetricPublisher() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.NoOpSystemMetricPublisher
 
NoOverCommitPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This policy enforce a simple physical cluster capacity constraints, by validating that the allocation proposed fits in the current plan.
NoOverCommitPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.NoOverCommitPolicy
 
normalizeAndValidateRequest(ResourceRequest, Resource, String, YarnScheduler, boolean, RMContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
normalizeAndValidateRequest(ResourceRequest, Resource, String, YarnScheduler, boolean, RMContext, QueueInfo) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
normalizeAndvalidateRequest(ResourceRequest, Resource, String, YarnScheduler, RMContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
normalizeAndvalidateRequest(ResourceRequest, Resource, String, YarnScheduler, RMContext, QueueInfo) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
normalizeAndValidateRequests(List<ResourceRequest>, Resource, String, YarnScheduler, RMContext) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Utility method to validate a list resource requests, by insuring that the requested memory/vcore is non-negative and not greater than max
normalizeRequest(ResourceRequest, ResourceCalculator, Resource, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility method to normalize a resource request, by insuring that the requested memory is a multiple of minMemory and is not zero.
normalizeResourceRequests(List<ResourceRequest>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Normalize a list of resource requests.
NOT_ABLE_TO_ACCESS_PARTITION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
NOT_SUFFICIENT_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
notifyFatalError(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
notifyNodeUpdate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
This will be called for each node heartbeat.
notifyStoreOperationFailed(Exception) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
This method is called to notify the ResourceManager that the store operation has failed.
notLeader() - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
NotSelf() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.NotSelf
 
NULL_ASSIGNMENT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
NullRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
NullRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
numActiveApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
numActiveApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
numApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
numCanFit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
numContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
numContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
numContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
numNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
numPendingApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
numPendingApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 

O

obtainSystemTokensForUser(String, Credentials) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
obtainType(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields.DeSelectType
Obtain the DeSelectType by the literals given behind deSelects in URL.
OFFSWITCH_PER_HEARTBEAT_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
onAMLaunchFailed(ContainerId, Exception) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
onInvalidStateTransition(RMAppEventType, RMAppState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
catch the InvalidStateTransition.
onInvalidTranstion(RMAppAttemptEventType, RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
onReload(AllocationConfiguration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService.Listener
 
openDatabase() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
OpportunisticContainerAllocatorAMService - Class in org.apache.hadoop.yarn.server.resourcemanager
The OpportunisticContainerAllocatorAMService is started instead of the ApplicationMasterService if opportunistic scheduling is enabled for the YARN cluster (either centralized or distributed opportunistic scheduling).
OpportunisticContainerAllocatorAMService(RMContext, YarnScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Ordering policy of queues
OrderingPolicy<S extends SchedulableEntity> - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
OrderingPolicy is used by the scheduler to order SchedulableEntities for container assignment and preemption.
orderingPolicyInfo - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
org.apache.hadoop.yarn.server.resourcemanager - package org.apache.hadoop.yarn.server.resourcemanager
 
org.apache.hadoop.yarn.server.resourcemanager.ahs - package org.apache.hadoop.yarn.server.resourcemanager.ahs
 
org.apache.hadoop.yarn.server.resourcemanager.amlauncher - package org.apache.hadoop.yarn.server.resourcemanager.amlauncher
 
org.apache.hadoop.yarn.server.resourcemanager.blacklist - package org.apache.hadoop.yarn.server.resourcemanager.blacklist
 
org.apache.hadoop.yarn.server.resourcemanager.federation - package org.apache.hadoop.yarn.server.resourcemanager.federation
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
org.apache.hadoop.yarn.server.resourcemanager.metrics - package org.apache.hadoop.yarn.server.resourcemanager.metrics
Package org.apache.hadoop.yarn.server.resourcemanager.metrics contains classes related to publishing app/container events to ATS.
org.apache.hadoop.yarn.server.resourcemanager.monitor - package org.apache.hadoop.yarn.server.resourcemanager.monitor
 
org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity - package org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
 
org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants - package org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants
Monitoring policies, used to check invariants.
org.apache.hadoop.yarn.server.resourcemanager.nodelabels - package org.apache.hadoop.yarn.server.resourcemanager.nodelabels
 
org.apache.hadoop.yarn.server.resourcemanager.placement - package org.apache.hadoop.yarn.server.resourcemanager.placement
 
org.apache.hadoop.yarn.server.resourcemanager.recovery - package org.apache.hadoop.yarn.server.resourcemanager.recovery
 
org.apache.hadoop.yarn.server.resourcemanager.recovery.records - package org.apache.hadoop.yarn.server.resourcemanager.recovery.records
 
org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb - package org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb
 
org.apache.hadoop.yarn.server.resourcemanager.reservation - package org.apache.hadoop.yarn.server.resourcemanager.reservation
 
org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions - package org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions
 
org.apache.hadoop.yarn.server.resourcemanager.reservation.planning - package org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
 
org.apache.hadoop.yarn.server.resourcemanager.resource - package org.apache.hadoop.yarn.server.resourcemanager.resource
 
org.apache.hadoop.yarn.server.resourcemanager.rmapp - package org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt - package org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event - package org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor - package org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor
Package org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor contains classes related to application monitor.
org.apache.hadoop.yarn.server.resourcemanager.rmcontainer - package org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
org.apache.hadoop.yarn.server.resourcemanager.rmnode - package org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler - package org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
Package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf contains classes related to capacity scheduler configuration management.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.common - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Package org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement contains classes related to scheduling containers using placement constraints.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm
Package org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement contains classes related to scheduling containers using placement constraints.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators
Package org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement contains classes related to scheduling containers using placement constraints.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
This Package contains classes related to constrained placement of Requests.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
Package o.a.h.yarn.server.resourcemanager.scheduler.constraint.processor contains classes related to scheduling containers using placement processor.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.event - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo
 
org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
Package org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement contains classes related to application monitor.
org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
 
org.apache.hadoop.yarn.server.resourcemanager.security - package org.apache.hadoop.yarn.server.resourcemanager.security
 
org.apache.hadoop.yarn.server.resourcemanager.security.authorize - package org.apache.hadoop.yarn.server.resourcemanager.security.authorize
 
org.apache.hadoop.yarn.server.resourcemanager.timelineservice - package org.apache.hadoop.yarn.server.resourcemanager.timelineservice
Package org.apache.hadoop.yarn.server.resourcemanager.timelineservice contains classes related to handling of app level collectors.
org.apache.hadoop.yarn.server.resourcemanager.webapp - package org.apache.hadoop.yarn.server.resourcemanager.webapp
 
org.apache.hadoop.yarn.server.resourcemanager.webapp.dao - package org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
OVERCOMMIT_TIMEOUT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 

P

parent - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractAutoCreatedLeafQueue
 
parent - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
parent - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
ParentQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
ParentQueue(CapacitySchedulerContext, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
parse(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
Parse namespace from a string.
parse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileParser
 
parse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileQueueParser
 
parse(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Returns SchedulingPolicy instance corresponding to the SchedulingPolicy passed as a string.
parseResourceConfigValue(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Parses a resource config value of a form like "1024", "1024 mb", or "1024 mb, 3 vcores".
PartitionQueueCapacitiesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
This class represents queue capacities for a given partition
PartitionQueueCapacitiesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
PartitionQueueCapacitiesInfo(String, float, float, float, float, float, float, float, Resource, Resource, Resource, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
PartitionResourcesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
This class represents queue/user resource usage info for a given partition
PartitionResourcesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
PartitionResourcesInfo(String, ResourceInfo, ResourceInfo, ResourceInfo, ResourceInfo, ResourceInfo, ResourceInfo) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
PATTERN_FOR_ABSOLUTE_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
PATTERN_FOR_PRIORITY_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser
 
pending - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
PendingAsk - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
PendingAsk is the class to include minimal information of how much resource to ask under constraints (e.g.
PendingAsk(ResourceSizing) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.PendingAsk
 
PendingAsk(Resource, int) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.PendingAsk
 
PendingAskUpdateResult - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
Result of a resource-request update.
PendingAskUpdateResult(PendingAsk, PendingAsk, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.PendingAskUpdateResult
 
pendingContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
pendingContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
pendingDeductReserved - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
pendingMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
pendingVirtualCores - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
PeriodicRLESparseResourceAllocation - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This data structure stores a periodic RLESparseResourceAllocation.
PeriodicRLESparseResourceAllocation(ResourceCalculator, Long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Constructor.
PeriodicRLESparseResourceAllocation(ResourceCalculator) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Constructor.
PeriodicRLESparseResourceAllocation(RLESparseResourceAllocation, Long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Constructor.
place(ConstraintPlacementAlgorithmInput, ConstraintPlacementAlgorithmOutputCollector) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.DefaultPlacementAlgorithm
 
place(ConstraintPlacementAlgorithmInput, ConstraintPlacementAlgorithmOutputCollector) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.ConstraintPlacementAlgorithm
The Algorithm is expected to compute the placement of the provided ConstraintPlacementAlgorithmInput and use the collector to aggregate any output.
placeApplication(ApplicationSubmissionContext, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementManager
 
PlacedSchedulingRequest - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
Class to encapsulate a Placed scheduling Request.
PlacedSchedulingRequest(SchedulingRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.PlacedSchedulingRequest
 
PlacementConstraintManager - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Interface for storing and retrieving placement constraints (see PlacementConstraint).
PlacementConstraintManagerService - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
The service that implements the PlacementConstraintManager interface.
PlacementConstraintManagerService() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManagerService
 
PlacementConstraintProcessor - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
An ApplicationMasterServiceProcessor that performs Constrained placement of Scheduling Requests.
PlacementConstraintProcessor() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.PlacementConstraintProcessor
 
PlacementConstraintsUtil - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
This class contains various static methods used by the Placement Algorithms to simplify constrained placement.
PlacementFactory - Class in org.apache.hadoop.yarn.server.resourcemanager.placement
Factory class for creating instances of PlacementRule.
PlacementManager - Class in org.apache.hadoop.yarn.server.resourcemanager.placement
 
PlacementManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementManager
 
PlacementRule - Class in org.apache.hadoop.yarn.server.resourcemanager.placement
 
PlacementRule() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementRule
 
Plan - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
A Plan represents the central data structure of a reservation system that maintains the "agenda" for the cluster.
plan(Plan, List<ReservationDefinition>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.Planner
Update the existing Plan, by adding/removing/updating existing reservations, and adding a subset of the reservation requests in the contracts parameter.
plan(Plan, List<ReservationDefinition>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.SimpleCapacityReplanner
 
PlanContext - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
This interface provides read-only access to configuration-type parameter for a plan.
PlanEdit - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
This interface groups the methods used to modify the state of a Plan.
PlanFollower - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
A PlanFollower is a component that runs on a timer, and synchronizes the underlying ResourceScheduler with the Plan(s) and viceversa.
Planner - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
 
PlanningAlgorithm - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
An abstract class that follows the general behavior of planning algorithms.
PlanningAlgorithm() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
PlanningException - Exception in org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions
Exception thrown by the admission control subsystem when there is a problem in trying to find an allocation for a user ReservationSubmissionRequest.
PlanningException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.PlanningException
 
PlanningException(Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.PlanningException
 
PlanningException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.PlanningException
 
PlanningQuotaException - Exception in org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions
This exception is thrown if the user quota is exceed while accepting or updating a reservation.
PlanningQuotaException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.PlanningQuotaException
 
PlanningQuotaException(Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.PlanningQuotaException
 
PlanningQuotaException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.PlanningQuotaException
 
PlanQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
This represents a dynamic queue managed by the ReservationSystem.
PlanQueue(CapacitySchedulerContext, String, CSQueue, CSQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
 
plans - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
planStepSize - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
policy - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
PopularTagsIterator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators
Traverse Scheduling requests with the most popular tags (count) first.
PopularTagsIterator(Collection<SchedulingRequest>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators.PopularTagsIterator
 
populateQueueCapacities(QueueCapacities, QueueResourceQuotas) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
populateQueueCapacities(QueueCapacities, QueueResourceQuotas) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
populateQueueResourceUsage(ResourceUsage) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
populateQueueResourceUsage(ResourceUsage) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
postDelegationToken(DelegationToken, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method posts a delegation token from the client, and it is reachable by using RMWSConsts.DELEGATION_TOKEN.
postDelegationToken(DelegationToken, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
postDelegationTokenExpiration(HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method updates the expiration for a delegation token from the client, and it is reachable by using RMWSConsts.DELEGATION_TOKEN_EXPIRATION.
postDelegationTokenExpiration(HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
postHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
precheckNode(SchedulerRequestKey, SchedulerNode, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
Pre-check node to see if it satisfy the given schedulerKey and scheduler mode.
precheckNode(SchedulerNode, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Does this AppPlacementAllocator accept resources on given node?
precheckNode(SchedulerNode, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
precheckNode(SchedulerNode, SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
PreemptableQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption
 
PreemptableQueue(PreemptableQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptableQueue
 
PreemptableQueue(Map<String, Resource>, Map<String, Map<ContainerId, RMContainer>>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptableQueue
 
PreemptableResourceCalculator - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Calculate how much resources need to be preempted for each queue, will be used by PreemptionCandidatesSelector
PreemptableResourceCalculator(CapacitySchedulerPreemptionContext, boolean, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptableResourceCalculator
PreemptableResourceCalculator constructor
PreemptableResourceScheduler - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Interface for a scheduler that supports preemption/killing
preemptContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
PREEMPTED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
preemptedResourceSecondsMap - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
PREEMPTION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether preemption is enabled.
PREEMPTION_MAX_IGNORED_OVER_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Maximum amount of resources above the target capacity ignored for preemption.
PREEMPTION_MONITORING_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Time in milliseconds between invocations of this policy
PREEMPTION_NATURAL_TERMINATION_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Given a computed preemption target, account for containers naturally expiring and preempt only this percentage of the delta.
PREEMPTION_OBSERVE_ONLY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
If true, run the policy but do not affect the cluster with preemption and kill events.
PREEMPTION_SELECT_CANDIDATES_FOR_RESERVED_CONTAINERS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
When calculating which containers to be preempted, we will try to preempt containers for reserved containers first.
PREEMPTION_THRESHOLD - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
PREEMPTION_TO_BALANCE_QUEUES_BEYOND_GUARANTEED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Should we allow queues continue grow after all queue reaches their guaranteed capacity.
PREEMPTION_WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Time in milliseconds between requesting a preemption from an application and killing the container.
PreemptionCandidatesSelector - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
 
preemptionContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptionCandidatesSelector
 
preemptionDisabled - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
PreemptionManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption
 
PreemptionManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AboutPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppAttemptPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppLogAggregationStatusPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ContainerPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.NodeLabelsPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RedirectionErrorPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMErrorsAndWarningsPage
 
preHead(Hamlet.HTML<HtmlPage.__>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
preValidateMoveApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
preValidateMoveApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
preValidateMoveApplication(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
preValidateMoveApplication(ApplicationId, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
 
PRIMARY_GROUP_MAPPING - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule
 
PrimaryGroup() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.PrimaryGroup
 
priority - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
PRIORITY_SKIPPED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
PRIORITY_SKIPPED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
Skip the priority, and look at other priorities of the same application
PRIORITY_SKIPPED_BECAUSE_NODE_PARTITION_DOES_NOT_MATCH_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
PRIORITY_SKIPPED_BECAUSE_NULL_ANY_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
PriorityComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
A Comparator which orders SchedulableEntities by priority.
PriorityComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.PriorityComparator
 
PriorityUtilizationQueueOrderingPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy
For two queues with the same priority: - The queue with less relative used-capacity goes first - today’s behavior.
PriorityUtilizationQueueOrderingPolicy(boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.PriorityUtilizationQueueOrderingPolicy
 
processRMProxyUsersConf(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Find all configs whose name starts with YarnConfiguration.RM_PROXY_USER_PREFIX, and add a record for each one by replacing the prefix with ProxyUsers.CONF_HADOOP_PROXYUSER
progress - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
ProportionalCapacityPreemptionPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
This class implement a SchedulingEditPolicy that is designed to be paired with the CapacityScheduler.
ProportionalCapacityPreemptionPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
ProportionalCapacityPreemptionPolicy(RMContext, CapacityScheduler, Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
ProportionalCapacityPreemptionPolicy.IntraQueuePreemptionOrderPolicy - Enum in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
IntraQueuePreemptionOrder will be used to define various priority orders which could be configured by admin.
pullContainerUpdates() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
Get and clear the list of containerUpdates accumulated across NM heartbeats.
pullContainerUpdates() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
pullJustFinishedContainers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Return a list of the last set of finished containers, resetting the finished containers to empty.
pullJustFinishedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
pullNewlyAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
pullNewlyDecreasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
pullNewlyDemotedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
pullNewlyIncreasedContainers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
pullNewlyIncreasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
pullNewlyIncreasedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
pullNewlyPromotedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
pullPreviousAttemptContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Called when AM heartbeats.
pullRMNodeLabelsInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
pullRMNodeUpdates(Map<RMNode, NodeUpdateType>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
To receive the collection of all RMNodes whose updates have been received by the RMApp.
pullRMNodeUpdates(Map<RMNode, NodeUpdateType>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
pullUpdateContainerErrors() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
pullUpdatedNMTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 

Q

qName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
qstate - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
qstateFormatted - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
queryRMNodes(RMContext, EnumSet<NodeState>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
Queue() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager.Queue
 
QUEUE() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.QUEUE
 
queue - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation.AssignmentDetails
 
Queue - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
queue - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
queue - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
queue - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
queue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
QUEUE_ACL_TYPE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
QUEUE_AM_RESOURCE_LIMIT_EXCEED - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
QUEUE_DO_NOT_NEED_MORE_RESOURCE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
QUEUE_GLOBAL_MAX_APPLICATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Maximum application for a queue to be used when application per queue is not defined.To be consistent with previous version the default value is set as UNDEFINED.
QUEUE_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
QUEUE_MANAGEMENT_MONITORING_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Time in milliseconds between invocations of this policy
QUEUE_MAPPING - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
QUEUE_MAX_CAPACITY_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
QUEUE_PREEMPTION_DISABLED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
QUEUE_PRIORITY_UTILIZATION_ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Combination of relative usage and priority
QUEUE_SKIPPED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
Skip the leaf-queue, and look at other queues of the same parent queue
QUEUE_SKIPPED_HEADROOM - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
QUEUE_UTILIZATION_ORDERING_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Less relative usage queue can get next resource, this is default
queueAcls(String, AccessType, AccessControlList) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
queueACLsManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
QueueACLsManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
 
QueueACLsManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.QueueACLsManager
 
QueueACLsManager(ResourceScheduler, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.QueueACLsManager
 
QueueAdminConfigurationMutationACLPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
A configuration mutation ACL policy which checks that user has admin privileges on all queues they are changing.
QueueAdminConfigurationMutationACLPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.QueueAdminConfigurationMutationACLPolicy
 
QueueCapacities - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
QueueCapacities(boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
queueCapacitiesByPartition - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
QueueCapacitiesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
DAO which wraps PartitionQueueCapacitiesInfo applicable for a queue
QueueCapacitiesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
QueueCapacitiesInfo(QueueCapacities, QueueResourceQuotas, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
QueueCapacitiesInfo(QueueCapacities, QueueResourceQuotas) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
QueueEntitlement - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
 
QueueEntitlement(float, float) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
queueEntity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
QueueInvalidException - Exception in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
QueueInvalidException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueInvalidException
 
QueueLimitCalculator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed
This class interacts with the NodeQueueLoadMonitor to keep track of the mean and standard deviation of the configured metrics (queue length or queue wait time) used to characterize the queue load of a specific node.
QueueManagementChange - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Encapsulates Queue entitlement and state updates needed for adjusting capacity dynamically
QueueManagementChange(CSQueue, QueueManagementChange.QueueAction) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
QueueManagementChange(CSQueue, QueueManagementChange.QueueAction, QueueState, AutoCreatedLeafQueueConfig) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
QueueManagementChange(CSQueue, QueueManagementChange.QueueAction, AutoCreatedLeafQueueConfig) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
QueueManagementChange.QueueAction - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Updating the queue may involve entitlement updates and/or QueueState changes QueueAction can potentially be enhanced for adding, removing queues for queue management
QueueManagementChange.UpdateQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
QueueManagementChangeEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
Event to update scheduler of any queue management changes
QueueManagementChangeEvent(ParentQueue, List<QueueManagementChange>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.QueueManagementChangeEvent
 
QueueManagementDynamicEditPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Queue Management scheduling policy for managed parent queues which enable auto child queue creation
QueueManagementDynamicEditPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
Instantiated by CapacitySchedulerConfiguration
QueueManagementDynamicEditPolicy(RMContext, CapacityScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
QueueManagementDynamicEditPolicy(RMContext, CapacityScheduler, Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
 
queueManagementPolicy - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
QueueManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Maintains a list of queues as well as scheduling parameters for each queue, such as guaranteed share allocations, from the fair scheduler config file.
QueueManager(FairScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
QueueMapping(UserGroupMappingPlacementRule.QueueMapping.MappingType, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
QueueMapping(UserGroupMappingPlacementRule.QueueMapping.MappingType, String, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
queueMaxAMShares(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
queueMaxApps(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
QueueMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
QueueMetrics(MetricsSystem, String, Queue, boolean, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
queueName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
queueName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
queueName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
queueName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
QueueOrderingPolicy - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy
This will be used by ParentQueue to decide allocation ordering of child queues.
queuePath - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
QueuePlacementPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
QueuePlacementPolicy(List<QueuePlacementRule>, Map<FSQueueType, Set<String>>, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementPolicy
 
QueuePlacementRule - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
QueuePlacementRule() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule
 
QueuePlacementRule.Default - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Places apps in the specified default queue.
QueuePlacementRule.NestedUserQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Places apps in queues with name of the submitter under the queue returned by the nested rule.
QueuePlacementRule.PrimaryGroup - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Places apps in queues by primary group of the submitter
QueuePlacementRule.Reject - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Rejects all apps
QueuePlacementRule.SecondaryGroupExistingQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Places apps in queues by secondary group of the submitter Match will be made on first secondary group that exist in queues
QueuePlacementRule.Specified - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Places apps in queues by requested queue of the submitter
QueuePlacementRule.User - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Places apps in queues by username of the submitter
queuePolicies(String, SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
QueuePriorityContainerCandidateSelector - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
 
QueueProperties - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation
This class is a value class, storing queue properties parsed from the allocation.xml config file.
QueueProperties.Builder - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation
Builder class for QueueProperties.
QueueResourceQuotas - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
QueueResourceQuotas by Labels for following fields by label - EFFECTIVE_MIN_CAPACITY - EFFECTIVE_MAX_CAPACITY This class can be used to track resource usage in queue/user/app.
QueueResourceQuotas() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
QUEUES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
queues - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
queues - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
QUEUES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
QueueStateManager<T extends SchedulerQueue,E extends ReservationSchedulerConfiguration> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
QueueStateManager which can be used by Scheduler to manage the queue state.
QueueStateManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueStateManager
 
queueUsagePercentage - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
queueWeights(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 

R

rack - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
RACK_LOCALITY_ADDITIONAL_DELAY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RACK_LOCALITY_FULL_RESET - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
rackLocalityDelayMs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Deprecated.
rackLocalityThreshold - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
rc - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptableResourceCalculator
 
rc - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
rc - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptionCandidatesSelector
 
readFields(DataInput) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
readLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
readLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
readLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
readLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
readLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
readLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
readRMDelegationTokenIdentifierData(DataInputStream) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreUtils
Returns the RM Delegation Token data from the DataInputStream as a RMDelegationTokenIdentifierData.
recalculateQueueUsageRatio(Resource, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Recalculate QueueUsage Ratio.
RecommissionNodeTransition(NodeState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.RecommissionNodeTransition
 
ReconnectNodeTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.ReconnectNodeTransition
 
RECORD_FACTORY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
RECORD_FACTORY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
 
recordAppActivityWithAllocation(ActivitiesManager, SchedulerNode, SchedulerApplicationAttempt, RMContainer, ActivityState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
recordAppActivityWithoutAllocation(ActivitiesManager, SchedulerNode, SchedulerApplicationAttempt, Priority, String, ActivityState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
recordContainerAllocationTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
recordContainerRequestTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
recordFactory - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
recordFactory - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
recordNextNodeUpdateActivities(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
recordQueueActivity(ActivitiesManager, SchedulerNode, String, String, ActivityState, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.QUEUE
 
recordRejectedAppActivityFromLeafQueue(ActivitiesManager, SchedulerNode, SchedulerApplicationAttempt, Priority, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
recordSkippedAppActivityWithoutAllocation(ActivitiesManager, SchedulerNode, SchedulerApplicationAttempt, Priority, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
recover(RMStateStore.RMState) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.recovery.Recoverable
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
recover(RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
Recoverable - Interface in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
recoverApplication(ApplicationStateData, RMStateStore.RMState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
recoverContainer(RMContainer, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
recoverContainer(Resource, SchedulerApplicationAttempt, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
recoverContainer(Resource, SchedulerApplicationAttempt, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
recoverContainer(SchedulerNode, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
recoverContainer(Resource, SchedulerApplicationAttempt, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
recoverContainer(Resource, SchedulerApplicationAttempt, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
recoverContainer(Resource, SchedulerApplicationAttempt, RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.Queue
Recover the state of the queue for a given container.
recoverContainer(SchedulerNode, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
recoverContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Recover a container.
recoverContainersOnNode(List<NMContainerStatus>, RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
recoverContainersOnNode(List<NMContainerStatus>, RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
recoverDrainingState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
recoverResourceRequestsForContainer(ContainerRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
RecoveryComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
A Comparator which orders SchedulableEntities by isRecovering flag.
RecoveryComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.RecoveryComparator
 
recursivelyComputeIdealAssignment(TempQueuePerPartition, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptableResourceCalculator
This method recursively computes the ideal assignment of resources to each level of the hierarchy.
RedirectionErrorPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
This class is used to display a message that the proxy request failed because of a redirection issue.
RedirectionErrorPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RedirectionErrorPage
 
referringAppIds - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
refreshAdminAcls(RefreshAdminAclsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshClusterMaxPriority(RefreshClusterMaxPriorityRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshMaximumAllocation(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
refreshNodeHostCount(int) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.blacklist.BlacklistManager
Refresh the number of NodeManagers available for scheduling.
refreshNodeHostCount(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.blacklist.DisabledBlacklistManager
 
refreshNodeHostCount(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.blacklist.SimpleBlacklistManager
 
refreshNodes(RefreshNodesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshNodes(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
refreshNodes(Configuration, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
refreshNodesForcefully() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
Forcefully decommission the nodes if they are in DECOMMISSIONING state
refreshNodesGracefully(Configuration, Integer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
Refresh the nodes gracefully
refreshNodesResources(RefreshNodesResourcesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshQueues(RefreshQueuesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshQueues(CSQueue, CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
refreshServiceAcls(RefreshServiceAclsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshServiceAcls(Configuration, PolicyProvider) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
refreshSuperUserGroupsConfiguration(RefreshSuperUserGroupsConfigurationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshUserToGroupsMappings(RefreshUserToGroupsMappingsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
register(Class<? extends Enum>, EventHandler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter.MultiThreadedDispatcher
 
register(Class<? extends Enum>, EventHandler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.MultiThreadedDispatcher
 
REGISTER_AM - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
registerApp(ApplicationId, ApplicationTimeoutType, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
registerAppAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
registerApplication(ApplicationId, Map<Set<String>, PlacementConstraint>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
registerApplication(ApplicationId, Map<Set<String>, PlacementConstraint>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Register all placement constraints of an application.
registerApplication(ApplicationAttemptId, SecretKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
registerApplicationAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
registerApplicationMaster(RegisterApplicationMasterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
registerApplicationMaster(ApplicationAttemptId, RegisterApplicationMasterRequest, RegisterApplicationMasterResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.AbstractPlacementProcessor
 
registerApplicationMaster(ApplicationAttemptId, RegisterApplicationMasterRequest, RegisterApplicationMasterResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.DisabledPlacementProcessor
 
registerApplicationMasterForDistributedScheduling(RegisterApplicationMasterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.OpportunisticContainerAllocatorAMService
 
registerMasterKey(ApplicationAttemptId, byte[]) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
registerNodeManager(RegisterNodeManagerRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
registerSubCluster(SubClusterRegisterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
registry - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
RegularContainerAllocator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator
Allocate normal (new) containers, considers locality/label, etc.
RegularContainerAllocator(FiCaSchedulerApp, ResourceCalculator, RMContext, ActivitiesManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.RegularContainerAllocator
 
reinit(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Initialize a queue by setting its queue-specific properties and its metrics.
reinitialize(RMContext, Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityReservationSystem
 
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.FairReservationSystem
 
reinitialize(Configuration, RMContext) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Re-initialize the ReservationSystem.
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueue
 
reinitialize(CapacitySchedulerContext, ParentQueue) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedQueueManagementPolicy
Reinitialize policy state ( if required )
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
reinitialize(CSQueue, Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Reinitialize the queue.
reinitialize(CSQueue, Resource, CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
 
reinitialize(CapacitySchedulerContext, ParentQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.queuemanagement.GuaranteedOrZeroCapacityOverTimePolicy
 
reinitialize(Configuration, RMContext, ResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementDynamicEditPolicy
Reinitializes queues(Called on scheduler.reinitialize)
reinitialize(CSQueue, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ReservationQueue
 
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
reinitialize(Configuration, RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
reinitialize(Configuration, RMContext) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler
Re-initialize the ResourceScheduler.
reinitializeFromTemplate(AutoCreatedLeafQueueConfig) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueue
 
reinitializeQueueLabels(Map<String, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
reinitializeQueues(CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
reinitializeQueues(E) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueueManager
Reinitialize the queues.
Reject() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Reject
 
rejoinElection() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
rejoinElection() - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
rejoinElection() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.EmbeddedElector
Leave and rejoin leader election.
RELEASE_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
releaseContainer(ContainerId, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
Release an allocated container on this node.
releaseContainer(ContainerId, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Release an allocated container on this node.
ReleaseContainerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
Event used to release a container.
ReleaseContainerEvent(RMContainer) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ReleaseContainerEvent
Create Event.
releaseContainers(List<ContainerId>, SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
RELEASED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
releaseResource(Resource, Resource, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
releaseResources(String, String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
releaseResources(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Release Resource for container size change.
reloadAllocations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
Updates the allocation list from the allocation config file.
reloadConfigurationFromStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.MutableCSConfigurationProvider
 
reloadConfigurationFromStore() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.MutableConfigurationProvider
Called when a new ResourceManager is starting/becomes active.
reloadProfiles() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManager
Reload profiles based on updated configuration.
reloadProfiles() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
remove(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher
 
REMOVE_NODE_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#removeFromCluserNodeLabels.
removeApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
removeApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeApplication(RMApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Non-blocking API ResourceManager services call this to remove an application from the state store This does not block the dispatcher threads There is no notification of completion for this operation.
removeApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived classes must implement this method to remove application from the state store
removeApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
removeApplicationAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Non-blocking API ResourceManager services call this to remove an attempt from the state store This does not block the dispatcher threads There is no notification of completion for this operation.
removeApplicationAttemptInternal(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeApplicationAttemptInternal(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
removeApplicationAttemptInternal(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeApplicationAttemptInternal(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeApplicationAttemptInternal(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to remove the state of specified attempt.
removeApplicationAttemptInternal(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
removeApplicationStateInternal(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeApplicationStateInternal(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
removeApplicationStateInternal(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeApplicationStateInternal(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeApplicationStateInternal(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to remove the state of an application and its attempts
removeApplicationStateInternal(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
removeAppPlacement(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
removeChildQueue(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
Remove the specified child queue.
removeChildQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
Remove the specified child queue.
removeCollectorData() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
removeContainer(NodeId, ContainerId, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Notify container removed.
removeFromCache(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
removeFromCluserNodeLabels(Set<String>, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method removes all the node labels for specific nodes, and it is reachable by using RMWSConsts.REMOVE_NODE_LABELS.
removeFromCluserNodeLabels(Set<String>, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
removeFromClusterNodeLabels(RemoveFromClusterNodeLabelsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
removeFromClusterNodeLabels(Collection<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
removeFromOutstandingUpdate(SchedulerRequestKey, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
Remove Container from outstanding increases / decreases.
removeGlobalConstraint(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
removeGlobalConstraint(Set<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Remove a global constraint that is associated with the given allocation tags.
removeInterval(ReservationInterval, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
Removes a resource for the specified interval.
removeInterval(ReservationInterval, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Removes a resource for the specified interval.
removeKillableContainer(KillableContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
removeLabelsFromNode(Map<NodeId, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
removeLeafQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Remove a leaf queue if empty
removeNode(RMNode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.ClusterMonitor
 
removeNode(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
removeNode(RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
removeNodeKey(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
This is to be called when NodeManager reconnects or goes down.
removeQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
removeQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
removeQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
removeQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Only supports removing empty leaf queues
removeQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueueManager
Remove the queue from the existing queue.
removeQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Remove an existing queue.
removeReservation(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
removeReservationState(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeReservationState(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
removeReservationState(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeReservationState(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeReservationState(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to remove the state of a reservation allocation.
removeReservationState(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
removeRMContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
removeRMDelegationToken(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
RMDTSecretManager call this to remove the state of a delegation token
removeRMDelegationTokenState(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeRMDelegationTokenState(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
removeRMDelegationTokenState(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeRMDelegationTokenState(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeRMDelegationTokenState(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to remove the state of RMDelegationToken
removeRMDelegationTokenState(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
removeRMDTMasterKey(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
RMDTSecretManager call this to remove the state of a master key
removeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
removeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to remove the state of DelegationToken Master Key
removeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
removeSchedulableEntity(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
removeSchedulableEntity(S) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.OrderingPolicy
Remove a SchedulableEntity from management for allocation and preemption ordering.
removeStoredMasterKey(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
removeStoredToken(RMDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
removeTags(NodeId, ApplicationId, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager
Helper method to just remove the tags associated with a container.
removeUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Remove user.
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AboutBlock
 
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ErrorBlock
 
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerAppsBlock
 
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.MetricsOverviewTable
 
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.NavBlock
 
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppBlock
 
render(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppLogAggregationStatusBlock
 
renderData(HtmlBlock.Block) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMAppsBlock
 
renewDelegationToken(RenewDelegationTokenRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
renewToken(DelegationTokenRenewer.DelegationTokenToRenew) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
reorderSchedulableEntity(S) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
reorderScheduleEntities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
REPLACE_NODE_TO_LABELS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#replaceLabelsOnNodes.
replaceFile(Path, Path) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
replaceLabelsOnNode(ReplaceLabelsOnNodeRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
replaceLabelsOnNode(Map<NodeId, Set<String>>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
replaceLabelsOnNode(Set<String>, HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method replaces all the node labels for specific node, and it is reachable by using RMWSConsts.NODES_NODEID_REPLACE_LABELS.
replaceLabelsOnNode(Set<String>, HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
replaceLabelsOnNodes(NodeToLabelsEntryList, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method replaces all the node labels for specific nodes, and it is reachable by using RMWSConsts.REPLACE_NODE_TO_LABELS.
replaceLabelsOnNodes(NodeToLabelsEntryList, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
reportNodeUnusable(RMNodeImpl, NodeState) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
Report node is UNUSABLE and update metrics.
REQUEST_CAN_NOT_ACCESS_NODE_LABEL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
requestPriority - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivityNodeInfo
 
RESERVABLE_NODES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Ratio of nodes available for an app to make an reservation on.
RESERVABLE_NODES_DEFAULT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
reservableQueues(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
RESERVATION_ADMISSION_POLICY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RESERVATION_AGENT_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RESERVATION_DELETE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#deleteReservation.
RESERVATION_ENFORCEMENT_WINDOW - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RESERVATION_ID - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
RESERVATION_LIST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#listReservation.
RESERVATION_MOVE_ON_EXPIRY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RESERVATION_NEW - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#createNewReservation.
RESERVATION_PLANNER_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RESERVATION_SHOW_RESERVATION_AS_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
RESERVATION_SUBMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#submitReservation.
RESERVATION_SYSTEM_ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RESERVATION_UPDATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#updateReservation.
RESERVATION_WINDOW - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
reservationAcls(String, ReservationACL, AccessControlList) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.QueueProperties.Builder
 
ReservationAgent - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
An entity that seeks to acquire resources to satisfy an user's contract
ReservationAllocation - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
A ReservationAllocation represents a concrete allocation of resources over time that satisfy a certain ReservationDefinition.
ReservationConstants - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
 
ReservationDefinitionInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class that represent a reservation definition.
ReservationDefinitionInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
ReservationDefinitionInfo(ReservationDefinition) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
ReservationDeleteRequestInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class represent the request of deleting a given reservation, selected by its id.
ReservationDeleteRequestInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDeleteRequestInfo
 
ReservationDeleteResponseInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class that represent a reponse to a delete operation.
ReservationDeleteResponseInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDeleteResponseInfo
 
ReservationInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class that represent a reservation.
ReservationInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
ReservationInfo(ReservationAllocationState, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
ReservationInputValidator - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
 
ReservationInputValidator(Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInputValidator
Utility class to validate reservation requests.
ReservationInterval - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This represents the time duration of the reservation
ReservationInterval(long, long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
 
ReservationInvariantsChecker - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants
Invariant checker that checks certain reservation invariants are respected.
ReservationInvariantsChecker() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.ReservationInvariantsChecker
 
ReservationListInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class that represent a list of reservations.
ReservationListInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationListInfo
 
ReservationListInfo(ReservationListResponse, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationListInfo
 
ReservationQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
This represents a dynamic LeafQueue managed by the ReservationSystem
ReservationQueue(CapacitySchedulerContext, String, PlanQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ReservationQueue
 
ReservationQueueConfiguration - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
ReservationQueueConfiguration() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
ReservationRequestInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class representing a reservation request.
ReservationRequestInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
ReservationRequestInfo(ReservationRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
ReservationRequestsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class representing a list of ReservationRequest and the interpreter which capture the semantic of this list (all/any/order).
ReservationRequestsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestsInfo
 
ReservationRequestsInfo(ReservationRequests) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestsInfo
 
ReservationsACLsManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
The ReservationsACLsManager is used to check a specified user's permissons to perform a reservation operation on the CapacityScheduler and the FairScheduler.
ReservationsACLsManager(ResourceScheduler, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.ReservationsACLsManager
 
ReservationSchedulerConfiguration - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
 
ReservationSchedulerConfiguration() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
ReservationSchedulerConfiguration(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSchedulerConfiguration
 
ReservationSubmissionRequestInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class to allow users to send information required to create an ReservationSubmissionContext which can then be used to submit a reservation.
ReservationSubmissionRequestInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
ReservationSystem - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
This interface is the one implemented by any system that wants to support Reservations i.e.
reservationSystem - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ReservationSystemUtil - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
Simple helper class for static methods used to transform across common formats in tests
ReservationUpdateRequestInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class to allow users to send information required to update an existing reservation.
ReservationUpdateRequestInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationUpdateRequestInfo
 
ReservationUpdateResponseInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class that represent the response to a reservation update request.
ReservationUpdateResponseInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationUpdateResponseInfo
 
reserve(SchedulerRequestKey, FiCaSchedulerNode, RMContainer, Container, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
reserve(SchedulerNode, SchedulerRequestKey, RMContainer, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
RESERVE_CONT_LOOK_ALL_NODES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
reserved - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
ReservedContainerCandidatesSelector - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
 
reservedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
reservedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
reservedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
reservedMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
reservedVirtualCores - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
reserveIncreasedContainer(SchedulerNode, SchedulerRequestKey, RMContainer, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
reserveResource(SchedulerApplicationAttempt, SchedulerRequestKey, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
reserveResource(SchedulerApplicationAttempt, SchedulerRequestKey, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
reserveResource(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
reserveResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
reserveResource(SchedulerApplicationAttempt, SchedulerRequestKey, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Reserve container for the attempt on this node.
resetLastNodeHeartBeatResponse() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
Reset lastNodeHeartbeatResponse's ID to 0.
resetLastNodeHeartBeatResponse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
resetMissedNonPartitionedRequestSchedulingOpportunity(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
resetReReservations(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
resetSchedulerMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
resetSchedulerMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
resetSchedulerMetrics() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler
Reset scheduler metrics.
resetSchedulingOpportunities(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
Should be called when an application has successfully scheduled a container, or when the scheduling locality threshold is relaxed.
resetSchedulingOpportunities(SchedulerRequestKey, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
resolve(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
resolve(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.DirectResolver
 
resolve(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.Resolver
 
resolve(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
resolving the network topology.
resource - Variable in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager.Queue
 
RESOURCE_CALCULATOR_CLASS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
ResourceComparator for scheduling.
ResourceAllocationCommitter - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
Scheduler should implement this interface if it wants to have multi-threading plus global scheduling functionality
ResourceAllocationInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class that represent a resource allocation.
ResourceAllocationInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
ResourceAllocationInfo(ReservationInterval, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
ResourceCommitRequest<A extends SchedulerApplicationAttempt,N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
 
ResourceCommitRequest(List<ContainerAllocationProposal<A, N>>, List<ContainerAllocationProposal<A, N>>, List<SchedulerContainer<A, N>>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
resourceInfo - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
ResourceInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ResourceInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
ResourceInfo(Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
resourceInformation - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInformationsInfo
 
ResourceInformationsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
ResourceInformationsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInformationsInfo
 
ResourceLimits - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Resource limits for queues/applications, this means max overall (please note that, it's not "extra") resource you can get.
ResourceLimits(Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
ResourceLimits(Resource, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
resourceManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
ResourceManager - Class in org.apache.hadoop.yarn.server.resourcemanager
The ResourceManager is the main class that is a set of components.
ResourceManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ResourceManager.ApplicationAttemptEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.ApplicationEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.NodeEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.RMActiveServices - Class in org.apache.hadoop.yarn.server.resourcemanager
RMActiveServices handles all the Active services in the RM.
resourceManagerBuildVersion - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
resourceManagerVersion - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
resourceManagerVersionBuiltOn - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
ResourceOverCommitException - Exception in org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions
This exception indicate that the reservation that has been attempted, would exceed the physical resources available in the Plan at the moment.
ResourceOverCommitException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.ResourceOverCommitException
 
ResourceOverCommitException(Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.ResourceOverCommitException
 
ResourceOverCommitException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.reservation.exceptions.ResourceOverCommitException
 
ResourceProfilesManager - Interface in org.apache.hadoop.yarn.server.resourcemanager.resource
Interface for the resource profiles manager.
ResourceProfilesManagerImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.resource
PBImpl class to handle all proto related implementation for ResourceProfilesManager.
ResourceProfilesManagerImpl() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
ResourceRequestInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
Simple class representing a resource request.
ResourceRequestInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
ResourceRequestInfo(ResourceRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
resources - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
resources - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
ResourceScheduler - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
This interface is the one implemented by the schedulers.
resourceSecondsMap - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
ResourcesInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
DAO which wraps PartitionResourceUsageInfo applicable for a queue/user
ResourcesInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourcesInfo
 
ResourcesInfo(ResourceUsage, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourcesInfo
 
ResourcesInfo(ResourceUsage) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourcesInfo
 
resourcesUsed - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
resourcesUsed - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
resourceTracker - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ResourceTrackerService - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceTrackerService(RMContext, NodesListManager, NMLivelinessMonitor, RMContainerTokenSecretManager, NMTokenSecretManagerInRM) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
ResourceUsage - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Resource Usage by Labels for following fields by label - AM resource (to enforce max-am-resource-by-label after YARN-2637) - Used resource (includes AM resource usage) - Reserved resource - Pending resource - Headroom This class can be used to track resource usage in queue/user/app.
ResourceUsage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
resourceUtilization - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
ResourceUtilizationInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
DAO object represents resource utilization of node and containers.
ResourceUtilizationInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
ResourceUtilizationInfo(RMNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceUtilizationInfo
 
RESPECT_FIFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
retrieve() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
retrieve() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
retrieve() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Retrieve the persisted configuration.
retrieve() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
retrievePassword(AMRMTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Retrieve the password for the given AMRMTokenIdentifier.
RLESparseResourceAllocation - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation
This is a run length encoded sparse data structure that maintains resource allocations over time.
RLESparseResourceAllocation(ResourceCalculator) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
RLESparseResourceAllocation(NavigableMap<Long, Resource>, ResourceCalculator) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
RLESparseResourceAllocation.RLEOperator - Enum in org.apache.hadoop.yarn.server.resourcemanager.reservation
The set of operators that can be applied to two RLESparseResourceAllocation during a merge operation.
RM_APP_ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RM_APP_ROOT_HIERARCHIES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
RM_DELEGATION_TOKENS_ROOT_ZNODE_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RM_DT_SECRET_MANAGER_ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RM_SCHEDULER_INCREMENT_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
The preferred way to configure the increment is by using the yarn.resource-types.{RESOURCE_NAME}.increment-allocation property, for memory: yarn.resource-types.memory-mb.increment-allocation
RM_SCHEDULER_INCREMENT_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Deprecated.
The preferred way to configure the increment is by using the yarn.resource-types.{RESOURCE_NAME}.increment-allocation property, for CPU: yarn.resource-types.vcores.increment-allocation
RM_SCHEDULER_RESERVATION_THRESHOLD_INCREMENT_MULTIPLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Threshold for container size for making a container reservation as a multiple of increment allocation.
RM_SYSTEM_CREDENTIALS_VALID_TIME_REMAINING - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
RM_WEB_SERVICE_PATH - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol.
RMActiveServiceContext - Class in org.apache.hadoop.yarn.server.resourcemanager
The RMActiveServiceContext is the class that maintains Active service context.
RMActiveServiceContext() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
RMActiveServiceContext(Dispatcher, ContainerAllocationExpirer, AMLivelinessMonitor, AMLivelinessMonitor, DelegationTokenRenewer, AMRMTokenSecretManager, RMContainerTokenSecretManager, NMTokenSecretManagerInRM, ClientToAMTokenSecretManagerInRM, ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
RMApp - Interface in org.apache.hadoop.yarn.server.resourcemanager.rmapp
The interface to an Application in the ResourceManager.
RMAppAttempt - Interface in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
Interface to an Application Attempt in the Resource Manager.
RMAppAttemptBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMAppAttemptContainerFinishedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptContainerFinishedEvent(ApplicationAttemptId, ContainerStatus, NodeId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerFinishedEvent
 
RMAppAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppAttemptEvent(ApplicationAttemptId, RMAppAttemptEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptEvent
 
RMAppAttemptEvent(ApplicationAttemptId, RMAppAttemptEventType, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptEvent
 
RMAppAttemptEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppAttemptImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppAttemptImpl(ApplicationAttemptId, RMContext, YarnScheduler, ApplicationMasterService, ApplicationSubmissionContext, Configuration, List<ResourceRequest>, RMApp) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
RMAppAttemptImpl(ApplicationAttemptId, RMContext, YarnScheduler, ApplicationMasterService, ApplicationSubmissionContext, Configuration, List<ResourceRequest>, RMApp, BlacklistManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
RMAppAttemptImpl.ScheduleTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppAttemptMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppAttemptMetrics(ApplicationAttemptId, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
RMAppAttemptRegistrationEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptRegistrationEvent(ApplicationAttemptId, String, int, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptRegistrationEvent
 
RMAppAttemptState - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppAttemptStatusupdateEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptStatusupdateEvent(ApplicationAttemptId, float) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptStatusupdateEvent
 
RMAppAttemptUnregistrationEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptUnregistrationEvent(ApplicationAttemptId, String, FinalApplicationStatus, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptUnregistrationEvent
 
RMAppBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppEvent(ApplicationId, RMAppEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppEvent
 
RMAppEvent(ApplicationId, RMAppEventType, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppEvent
 
RMAppEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppFailedAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppFailedAttemptEvent(ApplicationId, RMAppEventType, String, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppFailedAttemptEvent
 
RMAppImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppImpl(ApplicationId, RMContext, Configuration, String, String, String, ApplicationSubmissionContext, YarnScheduler, ApplicationMasterService, long, String, Set<String>, List<ResourceRequest>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
RMAppImpl(ApplicationId, RMContext, Configuration, String, String, String, ApplicationSubmissionContext, YarnScheduler, ApplicationMasterService, long, String, Set<String>, List<ResourceRequest>, ApplicationPlacementContext, long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
RMAppKillByClientEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
An event class that is used to help with logging information when an application KILL event is needed.
RMAppKillByClientEvent(ApplicationId, String, UserGroupInformation, InetAddress) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppKillByClientEvent
constructor to create an event used for logging during user driven kill invocations.
RMApplicationHistoryWriter - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
ResourceManager uses this class to write the information of RMApp, RMAppAttempt and RMContainer.
RMApplicationHistoryWriter() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
RMApplicationHistoryWriter.MultiThreadedDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
RMAppLifetimeMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor
This service will monitor the applications against the lifetime value given.
RMAppLifetimeMonitor(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
RMAppLogAggregationStatusBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
rmAppManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
RMAppManager - Class in org.apache.hadoop.yarn.server.resourcemanager
This class manages the list of applications for the resource manager.
RMAppManager(RMContext, YarnScheduler, ApplicationMasterService, ApplicationACLsManager, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
RMAppManagerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager
 
RMAppManagerEvent(ApplicationId, RMAppManagerEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAppManagerEvent
 
RMAppManagerEvent(ApplicationId, String, RMAppManagerEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAppManagerEvent
 
RMAppManagerEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager
 
RMAppMetrics - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppMetrics(Resource, int, int, Map<String, Long>, Map<String, Long>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppMetrics
 
RMAppNodeUpdateEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppNodeUpdateEvent(ApplicationId, RMNode, RMAppNodeUpdateEvent.RMAppNodeUpdateType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent
 
RMAppNodeUpdateEvent.RMAppNodeUpdateType - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppRecoverEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppRecoverEvent(ApplicationId, RMStateStore.RMState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRecoverEvent
 
RMAppRunningOnNodeEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppRunningOnNodeEvent(ApplicationId, NodeId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRunningOnNodeEvent
 
RMAppsBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMAppStartAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt
 
RMAppStartAttemptEvent(ApplicationAttemptId, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppStartAttemptEvent
 
RMAppState - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppToMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor
This class used for monitor application with applicationId+appTimeoutType.
RMAuditLogger - Class in org.apache.hadoop.yarn.server.resourcemanager
Manages ResourceManager audit logs.
RMAuditLogger() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger
 
RMAuditLogger.ArgsBuilder - Class in org.apache.hadoop.yarn.server.resourcemanager
Builder to create and pass a list of arbitrary key value pairs for logging.
RMAuditLogger.AuditConstants - Class in org.apache.hadoop.yarn.server.resourcemanager
 
RMContainer - Interface in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
Represents the ResourceManager's view of an application container.
rmContainer - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation.AssignmentDetails
 
RMContainerBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMContainerBlock(ResourceManager, View.ViewContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMContainerBlock
 
RMContainerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerEvent(ContainerId, RMContainerEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerEvent
 
RMContainerEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerFinishedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerFinishedEvent(ContainerId, ContainerStatus, RMContainerEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerFinishedEvent
 
RMContainerImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerImpl(Container, SchedulerRequestKey, ApplicationAttemptId, NodeId, String, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
RMContainerImpl(Container, SchedulerRequestKey, ApplicationAttemptId, NodeId, String, RMContext, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
RMContainerImpl(Container, SchedulerRequestKey, ApplicationAttemptId, NodeId, String, RMContext, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
RMContainerImpl(Container, SchedulerRequestKey, ApplicationAttemptId, NodeId, String, RMContext, long, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
RMContainerImpl(Container, SchedulerRequestKey, ApplicationAttemptId, NodeId, String, RMContext, long, String, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
RMContainerNMDoneChangeResourceEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerNMDoneChangeResourceEvent(ContainerId, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerNMDoneChangeResourceEvent
 
RMContainerRecoverEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerRecoverEvent(ContainerId, NMContainerStatus) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerRecoverEvent
 
RMContainerReservedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
The event signifying that a container has been reserved.
RMContainerReservedEvent(ContainerId, Resource, NodeId, SchedulerRequestKey) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerReservedEvent
 
RMContainerState - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerTokenSecretManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
SecretManager for ContainerTokens.
RMContainerTokenSecretManager(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
 
RMContainerUpdatesAcquiredEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
RMContainerUpdatesAcquiredEvent(ContainerId, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerUpdatesAcquiredEvent
 
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
"Always On" services.
RMContext - Interface in org.apache.hadoop.yarn.server.resourcemanager
Context of the ResourceManager.
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
 
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
RMContextImpl - Class in org.apache.hadoop.yarn.server.resourcemanager
RMContextImpl class holds two services context.
RMContextImpl() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
Default constructor.
RMContextImpl(Dispatcher, ContainerAllocationExpirer, AMLivelinessMonitor, AMLivelinessMonitor, DelegationTokenRenewer, AMRMTokenSecretManager, RMContainerTokenSecretManager, NMTokenSecretManagerInRM, ClientToAMTokenSecretManagerInRM, ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
RMContextImpl(Dispatcher, ContainerAllocationExpirer, AMLivelinessMonitor, AMLivelinessMonitor, DelegationTokenRenewer, AMRMTokenSecretManager, RMContainerTokenSecretManager, NMTokenSecretManagerInRM, ClientToAMTokenSecretManagerInRM) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
RmController - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMCriticalThreadUncaughtExceptionHandler - Class in org.apache.hadoop.yarn.server.resourcemanager
This class either shuts down ResourceManager or transitions the ResourceManager to standby state if a critical thread throws an uncaught exception.
RMCriticalThreadUncaughtExceptionHandler(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMCriticalThreadUncaughtExceptionHandler
 
RMDelegatedNodeLabelsUpdater - Class in org.apache.hadoop.yarn.server.resourcemanager.nodelabels
Update nodes labels map for ResourceManager periodically.
RMDelegatedNodeLabelsUpdater(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
 
RMDelegationTokenIdentifierData - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
 
RMDelegationTokenIdentifierData() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
RMDelegationTokenIdentifierData(YARNDelegationTokenIdentifier, long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
RMDelegationTokenSecretManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
A ResourceManager specific delegation token secret manager.
RMDelegationTokenSecretManager(long, long, long, long, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
Create a secret manager
rmDTSecretManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
RMDTSecretManagerState() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
RMErrorsAndWarningsPage - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMErrorsAndWarningsPage() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMErrorsAndWarningsPage
 
RMFatalEvent - Class in org.apache.hadoop.yarn.server.resourcemanager
Event that indicates a non-recoverable error for the resource manager.
RMFatalEvent(RMFatalEventType, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMFatalEvent
Create a new event of the given type with the given cause.
RMFatalEvent(RMFatalEventType, Exception) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMFatalEvent
Create a new event of the given type around the given source Exception.
RMFatalEvent(RMFatalEventType, Exception, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMFatalEvent
Create a new event of the given type around the given source Exception with the given cause.
RMFatalEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager
 
RMNMInfo - Class in org.apache.hadoop.yarn.server.resourcemanager
JMX bean listing statuses of all node managers.
RMNMInfo(RMContext, ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMNMInfo
Constructor for RMNMInfo registers the bean with JMX.
RMNMInfoBeans - Interface in org.apache.hadoop.yarn.server.resourcemanager
 
RMNode - Interface in org.apache.hadoop.yarn.server.resourcemanager.rmnode
Node managers information on available resources and other static information.
RMNodeCleanAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeCleanAppEvent(NodeId, ApplicationId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeCleanAppEvent
 
RMNodeCleanContainerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeCleanContainerEvent(NodeId, ContainerId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeCleanContainerEvent
 
RMNodeDecommissioningEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
RMNode Decommissioning Event.
RMNodeDecommissioningEvent(NodeId, Integer) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeDecommissioningEvent
 
RMNodeEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeEvent(NodeId, RMNodeEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeEvent
 
RMNodeEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeFinishedContainersPulledByAMEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeFinishedContainersPulledByAMEvent(NodeId, List<ContainerId>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeFinishedContainersPulledByAMEvent
 
RMNodeImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
This class is used to keep track of all the applications/containers running on a node.
RMNodeImpl(NodeId, RMContext, String, int, int, Node, Resource, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
RMNodeImpl(NodeId, RMContext, String, int, int, Node, Resource, String, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
RMNodeImpl.AddContainersToBeRemovedFromNMTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.AddNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.CleanUpAppTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.CleanUpContainerTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.DeactivateNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.DecommissioningNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
The transition to put node in decommissioning state.
RMNodeImpl.RecommissionNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.ReconnectNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.SignalContainerTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.StatusUpdateWhenHealthyTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
Status update transition when node is healthy.
RMNodeImpl.StatusUpdateWhenUnHealthyTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.UpdateContainersTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
Transition to Update a container.
RMNodeImpl.UpdateNodeResourceWhenRunningTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.UpdateNodeResourceWhenUnusableTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeLabelsManager - Class in org.apache.hadoop.yarn.server.resourcemanager.nodelabels
 
RMNodeLabelsManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
RMNodeLabelsManager.Queue - Class in org.apache.hadoop.yarn.server.resourcemanager.nodelabels
 
RMNodeLabelsMappingProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.nodelabels
Interface which is responsible for providing the node -> labels map.
RMNodeLabelsMappingProvider(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsMappingProvider
 
RMNodeReconnectEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeReconnectEvent(NodeId, RMNode, List<ApplicationId>, List<NMContainerStatus>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeReconnectEvent
 
RMNodeResourceUpdateEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeResourceUpdateEvent(NodeId, ResourceOption) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeResourceUpdateEvent
 
RMNodeSignalContainerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeSignalContainerEvent(NodeId, SignalContainerRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeSignalContainerEvent
 
RMNodeStartedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeStartedEvent(NodeId, List<NMContainerStatus>, List<ApplicationId>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStartedEvent
 
RMNodeStatusEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeStatusEvent(NodeId, NodeStatus) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
RMNodeStatusEvent(NodeId, NodeStatus, List<LogAggregationReport>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
RMNodeUpdateContainerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
This class is used to create update container event for the containers running on a node.
RMNodeUpdateContainerEvent(NodeId, Map<Container, ContainerUpdateType>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeUpdateContainerEvent
 
RMPolicyProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.security.authorize
PolicyProvider for YARN ResourceManager protocols.
RMQueueAclInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
RMQueueAclInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
RMQueueAclInfo(boolean, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
rmSecretManagerService - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
RMSecretManagerService - Class in org.apache.hadoop.yarn.server.resourcemanager
 
RMSecretManagerService(Configuration, RMContextImpl) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
Construct the service.
RMServerUtils - Class in org.apache.hadoop.yarn.server.resourcemanager
Utility methods to aid serving RM data through the REST and RPC APIs
RMServerUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
RMServiceContext - Class in org.apache.hadoop.yarn.server.resourcemanager
RMServiceContext class maintains "Always On" services.
RMServiceContext() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
RMState() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
RMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RMStateStore.RMDTSecretManagerState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStore.RMState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
State of the ResourceManager
RMStateStore.RMStateStoreState - Enum in org.apache.hadoop.yarn.server.resourcemanager.recovery
The enum defines state of RMStateStore.
RMStateStoreAMRMTokenEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreAMRMTokenEvent(RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAMRMTokenEvent
 
RMStateStoreAMRMTokenEvent(AMRMTokenSecretManagerState, boolean, RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAMRMTokenEvent
 
RMStateStoreAppAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreAppAttemptEvent(ApplicationAttemptStateData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAppAttemptEvent
 
RMStateStoreAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreAppEvent(ApplicationStateData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAppEvent
 
RMStateStoreEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreEvent(RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreEvent
 
rmStateStoreEventHandler - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RMStateStoreEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreFactory - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreFactory() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreFactory
 
rmStateStoreName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
RMStateStoreRemoveAppAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
A event used to remove an attempt.
RMStateStoreRemoveAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreRMDTEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreRMDTEvent(RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTEvent
 
RMStateStoreRMDTEvent(RMDelegationTokenIdentifier, Long, RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTEvent
 
RMStateStoreRMDTMasterKeyEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreRMDTMasterKeyEvent(RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTMasterKeyEvent
 
RMStateStoreRMDTMasterKeyEvent(DelegationKey, RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRMDTMasterKeyEvent
 
RMStateStoreStoreReservationEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
Event representing maintaining ReservationSystem state.
RMStateStoreStoreReservationEvent(RMStateStoreEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreStoreReservationEvent
 
RMStateStoreStoreReservationEvent(YarnProtos.ReservationAllocationStateProto, RMStateStoreEventType, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreStoreReservationEvent
 
RMStateStoreUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
Utility methods for RMStateStore and subclasses.
RMStateStoreUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreUtils
 
RMStateUpdateAppAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateUpdateAppAttemptEvent(ApplicationAttemptStateData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppAttemptEvent
 
RMStateUpdateAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateUpdateAppEvent(ApplicationStateData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppEvent
 
RMStateUpdateAppEvent(ApplicationStateData, boolean, SettableFuture<Object>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateUpdateAppEvent
 
RMStateVersionIncompatibleException - Exception in org.apache.hadoop.yarn.server.resourcemanager.recovery
This exception is thrown by ResourceManager if it's loading an incompatible version of storage on recovery.
RMStateVersionIncompatibleException(Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateVersionIncompatibleException
 
RMStateVersionIncompatibleException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateVersionIncompatibleException
 
RMStateVersionIncompatibleException(String, Throwable) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateVersionIncompatibleException
 
RMTimelineCollectorManager - Class in org.apache.hadoop.yarn.server.resourcemanager.timelineservice
This class extends TimelineCollectorManager to provide RM specific implementations.
RMTimelineCollectorManager(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.timelineservice.RMTimelineCollectorManager
 
RmView - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RmView() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
RMWebApp - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
The RM webapp
RMWebApp(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
RMWebAppFilter - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMWebAppFilter(Injector, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebAppFilter
 
RMWebAppUtil - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
Util class for ResourceManager WebApp.
RMWebServiceProtocol - Interface in org.apache.hadoop.yarn.server.resourcemanager.webapp
The protocol between clients and the ResourceManager to submit/abort jobs and to get information on applications, cluster metrics, nodes, queues, ACLs and reservations via REST calls.
RMWebServices - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMWebServices(ResourceManager, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
RMWSConsts - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
Constants for RMWebServiceProtocol.
rollbackContainerUpdate(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Rollback container update after expiry.
rollMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
Creates a new master-key and sets it as the primary.
rollMasterKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
Creates a new master-key and sets it as the primary.
ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.allocation.AllocationFileQueueParser
 
root - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeAllocationInfo
 
ROOT_DIR_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
ROOT_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
ROOT_ZNODE_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
run() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
run() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreHeartbeat
 
run() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
runAppAttempt(ApplicationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
runningContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 

S

SchedContainerChangeRequest - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
This is UpdateContainerRequest in scheduler side, it contains some pointers to runtime objects like RMContainer, SchedulerNode, etc.
SchedContainerChangeRequest(RMContext, SchedulerNode, RMContainer, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
Schedulable - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
A Schedulable represents an entity that can be scheduled such as an application or a queue.
schedulableEntities - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
SchedulableEntity - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy
A SchedulableEntity is a process to be scheduled.
SCHEDULE_ASYNCHRONOUSLY_ENABLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
SCHEDULE_ASYNCHRONOUSLY_MAXIMUM_PENDING_BACKLOGS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
SCHEDULE_ASYNCHRONOUSLY_MAXIMUM_THREAD - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
SCHEDULE_ASYNCHRONOUSLY_PREFIX - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
scheduler - Variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
scheduler - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
scheduler - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.AbstractPlacementProcessor
 
scheduler - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
scheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
SCHEDULER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getSchedulerInfo.
SCHEDULER_ACTIVITIES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getActivities.
SCHEDULER_APP_ACTIVITIES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#getAppActivities.
SCHEDULER_LOGS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
Path for RMWebServiceProtocol#dumpSchedulerLogs.
SchedulerApplication<T extends SchedulerApplicationAttempt> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
SchedulerApplication(Queue, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
SchedulerApplication(Queue, String, Priority) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
SchedulerApplicationAttempt - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents an application attempt from the viewpoint of the scheduler.
SchedulerApplicationAttempt(ApplicationAttemptId, String, Queue, AbstractUsersManager, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
SchedulerApplicationAttempt.AMState - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Different state for Application Master, user can see this state from web UI
SchedulerAppReport - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents an application attempt, and the resources that the attempt is using.
SchedulerAppReport(SchedulerApplicationAttempt) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppReport
 
SchedulerAppUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
SchedulerAppUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppUtils
 
SchedulerContainer<A extends SchedulerApplicationAttempt,N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common
Contexts for a container inside scheduler
SchedulerContainer(A, N, RMContainer, String, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
schedulerContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
 
SchedulerDynamicEditException - Exception in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
SchedulerDynamicEditException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerDynamicEditException
 
SchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
SchedulerEvent(SchedulerEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.SchedulerEvent
 
SchedulerEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
schedulerHealth - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
SchedulerHealth - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
SchedulerHealth() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
SchedulerHealth.DetailedInformation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
SchedulerInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
SchedulerInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
SchedulerInfo(ResourceManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
schedulerInfo - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerTypeInfo
 
schedulerName - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
SchedulerNode - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents a YARN Cluster Node from the viewpoint of the scheduler.
SchedulerNode(RMNode, boolean, Set<String>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
SchedulerNode(RMNode, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
SchedulerNodeReport - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Node usage report.
SchedulerNodeReport(SchedulerNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNodeReport
 
SchedulerPageUtil - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
SchedulerPageUtil() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.SchedulerPageUtil
 
SchedulerPlacementProcessor - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor
Forwarding SchedulingRequests to be handled by the scheduler, as long as the scheduler supports SchedulingRequests.
SchedulerPlacementProcessor() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.SchedulerPlacementProcessor
 
SchedulerQueue<T extends SchedulerQueue> - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents a queue in Scheduler.
SchedulerQueueManager<T extends SchedulerQueue,E extends ReservationSchedulerConfiguration> - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Context of the Queues in Scheduler.
schedulerRequestKey - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
 
SchedulerTypeInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
SchedulerTypeInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerTypeInfo
 
SchedulerTypeInfo(SchedulerInfo) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerTypeInfo
 
SchedulerUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Utilities shared by schedulers.
SchedulerUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
ScheduleTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl.ScheduleTransition
 
SchedulingEditPolicy - Interface in org.apache.hadoop.yarn.server.resourcemanager.monitor
 
SchedulingMode - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Scheduling modes, see below for detailed explanations
SchedulingMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor
 
SchedulingMonitor(RMContext, SchedulingEditPolicy) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
SchedulingMonitorManager - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor
Manages scheduling monitors.
SchedulingMonitorManager() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
schedulingMonitorManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
SchedulingPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
The SchedulingPolicy is used by the fair scheduler mainly to determine what a queue's fair share and steady fair share should be as well as calculating available headroom.
SchedulingPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
SchedulingRequestWithPlacementAttempt - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
Simple holder class encapsulating a SchedulingRequest with a placement attempt.
SchedulingRequestWithPlacementAttempt(int, SchedulingRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingRequestWithPlacementAttempt
 
schedulingResourceTypes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerInfo
 
SchedulingResponse - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api
This class encapsulates the response received from the ResourceScheduler's attemptAllocateOnNode method.
SchedulingResponse(boolean, ApplicationId, SchedulingRequest) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingResponse
Create a SchedulingResponse.
SCHEME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
SecondaryGroupExistingQueue() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.SecondaryGroupExistingQueue
 
selectCandidates(Map<ApplicationAttemptId, Set<RMContainer>>, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoCandidatesSelector
 
selectCandidates(Map<ApplicationAttemptId, Set<RMContainer>>, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.IntraQueueCandidatesSelector
 
selectCandidates(Map<ApplicationAttemptId, Set<RMContainer>>, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptionCandidatesSelector
Get preemption candidates from computed resource sharing and already selected candidates.
selectCandidates(Map<ApplicationAttemptId, Set<RMContainer>>, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.QueuePriorityContainerCandidateSelector
 
selectCandidates(Map<ApplicationAttemptId, Set<RMContainer>>, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ReservedContainerCandidatesSelector
 
selectLeastLoadedNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
Returns 'K' of the least Loaded Node Ids as ordered list.
selectNodes(NodeFilter) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.NodeCandidateSelector
Select a list of nodes given a filter.
selectNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
Returns all Node Ids as ordered list from Least to Most Loaded.
Self() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.Self
 
SerialIterator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators
Traverse Scheduling Requests in the same order as they arrive
SerialIterator(Collection<SchedulingRequest>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.algorithm.iterators.SerialIterator
 
server - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NMLivelinessMonitor
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.RMActiveServices
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.AMLivelinessMonitor
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.ContainerAllocationExpirer
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.RMActiveServices
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ActiveStandbyElectorBasedElectorService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.CuratorBasedElectorService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
Terminate the timer.
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager.CachedResolver
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.RMActiveServices
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMSecretManagerService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
setAbsoluteCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setAbsoluteCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setAbsoluteCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setAbsoluteMaxCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setAbsoluteMaximumCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteMaximumCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteReservedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteReservedCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteUsedCapacity(String, Float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
setAbsoluteUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteUsedCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setAbsoluteUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setAcceptanceTimestamp(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
setAcceptanceTimestamp(long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Sets the time at which the reservation was accepted by the system
setAccessibleNodeLabels(String, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAcl(String, QueueACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setACLList(AccessControlList) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
setAcls(String, Map<QueueACL, AccessControlList>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAcls(HashMap<ApplicationAccessType, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
setActiveNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setActuallyToBePreempted(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
setAggregatedContainersUtilization(ResourceUtilization) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setAggregatedContainersUtilization(ResourceUtilization) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Set the resource utilization of the containers in the node.
setAlgStageAllocator(StageAllocator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
setAlgStageExecutionInterval(StageExecutionInterval) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
setAllocatedMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setAllocatedMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAllocatedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
setAllocatedVCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setAllocatedVirtualCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAllocateResponse(AllocateResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService.AllocateResponseLock
 
setAllocationTags(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
setAllocationTagsManager(AllocationTagsManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setAllocationTagsManager(AllocationTagsManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setAllocationTagsManager(AllocationTagsManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setAllowed(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
setAMContainer(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
setAMContainerExitStatus(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setAMContainerExitStatus(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setAMContainerNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setAMHostHttpAddress(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setAMLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setAMLimit(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setAMLimit(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setAmountNeededUnreserve(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
setAMResouceLimit(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
setAMResouceLimitForUser(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
setAMResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setAMResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setAMResourceUsage(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Set the AM resource usage.
setAMRMToken(Token<AMRMTokenIdentifier>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
setAmRunning(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setAMUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setAMUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setAmUsed(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setAndUpdateNodeHeartbeatResponse(NodeHeartbeatResponse) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
Update a NodeHeartbeatResponse with the list of containers and applications to clean up for this node, and the containers to be updated.
setAndUpdateNodeHeartbeatResponse(NodeHeartbeatResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setAndUpdateUsageRatio(ResourceCalculator, Resource, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
setAppAMNodePartitionName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setAppAttemptTokens(Credentials) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setAppAttemptTokens(Credentials) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setAppId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setApplication(FiCaSchedulerApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setApplicationAttemptHeadRoom(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
setApplicationHeadroomForMetrics(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setApplicationId(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.NotSelf
The scope of self namespace is to an application itself, the application ID can be delay binding to the namespace.
setApplicationId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setApplicationName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setApplicationPriority(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
setApplicationSubmissionContext(ApplicationSubmissionContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setApplicationSubmissionContext(ApplicationSubmissionContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setApplicationTags(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setApplicationTimeouts(Map<ApplicationTimeoutType, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setApplicationTimeouts(Map<ApplicationTimeoutType, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setApplicationType(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setAppNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setAppsCompleted(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAppsFailed(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAppsKilled(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAppsPending(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAppsRunning(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAppsSubmitted(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setArrival(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
setAttemptFailuresValidityInterval(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setAttemptId(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setAttemptLastResponseId(ApplicationAttemptId, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
setAttemptRecovering(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setAutoCreateChildQueueEnabled(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueConfigCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueConfigDefaultNodeLabelExpression(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueConfigMaxCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueConfigUserLimit(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueConfigUserLimitFactor(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueTemplateCapacityByLabel(String, String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAutoCreatedLeafQueueTemplateMaxCapacity(String, String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAuxillaryServiceData(HashMap<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
setAvailableMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAvailableResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
setAvailableResource(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
setAvailableResourcesToQueue(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Set available resources.
setAvailableResourcesToQueue(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Set available resources.
setAvailableResourcesToUser(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Set available resources.
setAvailableVirtualCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setAverageCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAverageCapacity(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
setAverageCapacity(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
setCachedPending(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setCachedPending(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setCachedUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setCachedUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setCallerContext(CallerContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setCallerContext(CallerContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setCancelTokensWhenComplete(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setCapability(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
setCapability(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
setCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setCapacityByLabel(String, String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setCapacitySchedulerContext(CapacitySchedulerContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
Set the CapacitySchedulerContext.
setClientRMService(ClientRMService) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setClientRMService(ClientRMService) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setClientRMService(ClientRMService) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setClock(Clock) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
setClusterMaxPriority(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
setClusterMaxPriority(Configuration) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Set the cluster max priority
setClusterTimeStamp(long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
setCollectorData(AppCollectorData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
setCommands(List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
setConf(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
setConf(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
setConfigurationProvider(ConfigurationProvider) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setConfigurationProvider(ConfigurationProvider) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
setConfiguredMaxAllocation(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
setConfiguredMaxAllocationWaitTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
 
setConfiguredMaxResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setConfiguredMaxResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setConfiguredMinResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setConfiguredMinResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
setContainerId(ContainerId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
setContainerId(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
setContainerLaunchContextInfo(ContainerLaunchContextInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setContainerQueueLimitCalculator(QueueLimitCalculator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setContainerQueueLimitCalculator(QueueLimitCalculator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setContainerRequest(ContainerRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
setContainersAllocated(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setContainersPending(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setContainersReserved(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setContainersToKill(List<RMContainer>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setCredentials(CredentialsInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
setCurrentAppAttempt(T) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
setCurrentMasterKey(MasterKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
 
setCurrentMasterKey(MasterKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
setDeadline(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
setDecommisionedNMs(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
setDecommissionedNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setDecommissioningNMs(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
setDecommissioningNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setDefaultLifetimePerQueue(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setDefaultNodeLabelExpression(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setDefaultPriority(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppState
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
setDisplayPerUserApps(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
setDrainEventsOnStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ahs.RMApplicationHistoryWriter.MultiThreadedDispatcher
 
setDrainEventsOnStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.MultiThreadedDispatcher
 
setDuration(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
setEffectiveMaxResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setEffectiveMaxResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setEffectiveMinResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setEffectiveMinResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueResourceQuotas
 
setEndTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
setEndTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
setEnforceExecutionType(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ExecutionTypeRequestInfo
 
setEntitlement(String, QueueEntitlement) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
setEntitlement(QueueEntitlement) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractAutoCreatedLeafQueue
This methods to change capacity for a queue and adjusts its absoluteCapacity
setEntitlement(String, QueueEntitlement) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractAutoCreatedLeafQueue
This methods to change capacity for a queue and adjusts its absoluteCapacity
setEntitlement(String, QueueEntitlement) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
setEntitlement(String, QueueEntitlement) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
setEntitlement(String, QueueEntitlement) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
This method increase the entitlement for current queue (must respect invariants, e.g., no overcommit of parents, non negative, etc.).
setEnvironment(HashMap<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
setEpoch(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
setEpoch(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.EpochPBImpl
 
setExcessReservation(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setExcludePattern(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
setExecutionType(ExecutionType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ExecutionTypeRequestInfo
 
setExecutionTypeRequest(ExecutionTypeRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setExpiryTime(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
setFairShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
setFairShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setFairShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setFairShare(Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Assign a fair share to this Schedulable.
setFinalApplicationStatus(FinalApplicationStatus) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setFinalApplicationStatus(FinalApplicationStatus) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setFinalTrackingUrl(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Set the final tracking Url of the AM.
setFinalTrackingUrl(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setFinishTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setFinishTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setFinishTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setFinishTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setFSContext(FSContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
 
setFulfilledReservation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setFulfilledReservedContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setGlobalMaximumApplicationsPerQueue(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setHeadroom(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
setHeadroom(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setHeadroomProvider(CapacityHeadroomProvider) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
setHealthReport(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setHttpPort(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
setIdentifier(YARNDelegationTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
setIncludePattern(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
setIncreasedAllocation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setInstantaneousMaxCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setIsAllowPreemption(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
setIsPreempted() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
setKeepContainersAcrossApplicationAttempts(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setKind(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
setLastHealthReportTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setLastHealthUpdate(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
setLastNodeUpdateTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
setLeaderElectorService(EmbeddedElector) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setLeaderElectorService(EmbeddedElector) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setLeaderElectorService(EmbeddedElector) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
setLeafQueue(LeafQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
setLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceLimits
 
setLogAggregationContextInfo(LogAggregationContextInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setLogAggregationPolicyClassName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
setLogAggregationPolicyParameters(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
setLogAggregationReportsForApps(List<LogAggregationReport>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStartedEvent
 
setLogAggregationReportsForApps(List<LogAggregationReport>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
setLostNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setMasterContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setMasterContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setMasterContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
setMasterNodeId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setMaxAMLimitPercentage(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setMaxAMResourcePercentage(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setMaxAMResourcePercentage(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setMaxAMResourcePerQueuePercent(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setMaxAMShare(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setMaxAMShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
Set the maximum resource AM can use.
setMaxAppAttempts(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setMaxApplications(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setMaxApplicationsPerUser(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setMaxApps(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setMaxCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.QueueEntitlement
 
setMaxCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setMaxChildQueueResource(ConfigurableResource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setMaximumAMResourcePercentPerPartition(String, String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaximumApplicationMasterResourcePerQueuePercent(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaximumCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaximumCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setMaximumCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setMaximumCapacityByLabel(String, String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaximumKillWaitTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.PreemptionCandidatesSelector
 
setMaximumLifetimePerQueue(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaximumResourceRequirement(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaxPriority(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLGroup
 
setMaxRunningApps(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setMaxShare(ConfigurableResource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setMaxShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setMaxValidity(Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
setMemory(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
setMemoryPerNode(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
setMemorySeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setMemorySeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setMemorySeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setMinConcurrency(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
setMinimumResourceRequirement(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMinShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setMinShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setNextExpirationTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
setNextHeartBeat(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setNextMasterKey(MasterKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.AMRMTokenSecretManagerState
 
setNextMasterKey(MasterKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.AMRMTokenSecretManagerStatePBImpl
 
setNodeHTTPAddress(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
setNodeLabelExpression(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setNodeLabelManager(RMNodeLabelsManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setNodeLabelManager(RMNodeLabelsManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setNodeLabelManager(RMNodeLabelsManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setNodeLabelsInfo(ArrayList<NodeLabelInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeLabelsInfo
 
setNodeLocalityDelay(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setNodeRemovalCheckInterval(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
setNodes(String[]) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
setNodeUtilization(ResourceUtilization) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setNodeUtilization(ResourceUtilization) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Set the resource utilization of the node.
setNumAMContainerPreempted(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setNumContainers(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestInfo
 
setNumContainers(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setNumNonAMContainerPreempted(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setOffSwitchPerHeartbeatLimit(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setOpportunisticContainerContext(OpportunisticContainerContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setOpportunisticContainersStatus(OpportunisticContainersStatus) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setOrderingPolicy(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setOrderingPolicyParameter(String, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setOverCommitTimeoutPerNode(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
setOverrideWithQueueMappings(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setOwner(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
setParent(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
setParent(CSQueue) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Set the parent Queue.
setPartitionName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setPartitionName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setPartitionResourceUsages(List<PartitionResourcesInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourcesInfo
 
setPattern(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
setPending(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
setPending(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setPending(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setPending(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setPeriodicity(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
setPeriodicity(long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationAllocation
Set the periodicity of this reservation representing the time period of the periodic job.
setPhysicalResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setPlacementAttempt(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.PlacedSchedulingRequest
 
setPlacementConstraintManager(PlacementConstraintManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setPlacementConstraintManager(PlacementConstraintManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setPlacementConstraintManager(PlacementConstraintManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setPlanner(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
setPlans(Collection<Plan>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
setPlans(Collection<Plan>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanFollower
Setter for the list of plans.
setPolicy(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setPolicyConfiguration(SetSubClusterPolicyConfigurationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
setPreemptedMemorySeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setPreemptedMemorySeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setPreemptedMemorySeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setPreemptedResourceMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setPreemptedResourceSecondsMap(Map<String, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Set the aggregated number of resources preempted that the application has allocated times the number of seconds the application has been running.
setPreemptedResourceSecondsMap(Map<String, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setPreemptedResourceVCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setPreemptedVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setPreemptedVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setPreemptedVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setPreemptionDisabled(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Sets the disable_preemption property in order to indicate whether or not container preemption will be disabled for the specified queue.
setPriority(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
setPriority(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
setPriority(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setPriority(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppPriority
 
setPriority(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
setPriority(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setPriorityAcls(String, Priority, Priority, String[]) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setPUOrderingPolicyUnderUtilizedPreemptionDelay(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setPUOrderingPolicyUnderUtilizedPreemptionEnabled(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setPUOrderingPolicyUnderUtilizedPreemptionMoveReservation(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setQueue(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Reflects a change in the application's queue from the one specified in the ApplicationSubmissionContext.
setQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
setQueue(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
setQueue(Queue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
setQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppQueue
 
setQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
setQueueAcls(YarnAuthorizationProvider, AppPriorityACLsManager, Map<String, CSQueue>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerQueueManager
 
setQueueCapacitiesByPartition(List<PartitionQueueCapacitiesInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.QueueCapacitiesInfo
 
setQueueEntitlement(String, String, float, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
setQueueForReservation(ReservationId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
setQueueForReservation(ReservationId, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Set the Queue that an existing ReservationId should be associated with.
setQueueMappings(List<UserGroupMappingPlacementRule.QueueMapping>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setQueueName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
setQueueOrderingPolicy(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setQueuePlacementManager(PlacementManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setQueuePlacementManager(PlacementManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setQueuePlacementManager(PlacementManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setQueuePlacementRules(Collection<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setQueuePriority(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setQueues(String, String[]) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setQueues(List<CSQueue>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.PriorityUtilizationQueueOrderingPolicy
 
setQueues(List<CSQueue>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.policy.QueueOrderingPolicy
 
setRebootedNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setRecoveredFinalState(RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
setRecurrenceExpression(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
setRelaxLocality(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setReloadListener(AllocationFileLoaderService.Listener) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
setRemainingTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
setRenewDate(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
setRenewer(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
setRequestLocalityType(NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setReservable(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setReservationAcls(String, Map<ReservationACL, AccessControlList>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setReservationAdmissionPolicy(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setReservationAdmissionPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
setReservationAgent(String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setReservationAgent(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
setReservationDefinition(ReservationDefinitionInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
setReservationDefinition(ReservationDefinitionInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationUpdateRequestInfo
 
setReservationId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setReservationId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDeleteRequestInfo
 
setReservationId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationSubmissionRequestInfo
 
setReservationId(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationUpdateRequestInfo
 
setReservationName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
setReservationRequest(ArrayList<ReservationRequestInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestsInfo
 
setReservationRequests(ReservationRequestsInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationDefinitionInfo
 
setReservationRequestsInterpreter(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationRequestsInfo
 
setReservationWindow(String, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setReservationWindow(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationConfiguration
 
setReservationWindow(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
setReserved(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setReserved(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setReserved(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setReservedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setReservedCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setReservedContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
setReservedContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Set the reserved container in the node.
setReservedMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setReservedMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setReservedResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
setReservedVCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setReservedVirtualCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setResource(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setResource(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
setResourceCalculator(ResourceCalculator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
setResourceComparator(Class<? extends ResourceCalculator>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setResourceLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
setResourceManager(ResourceManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
setResourceManager(ResourceManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setResourceManager(ResourceManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
setResourceName(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceRequestInfo
 
setResourceProfilesManager(ResourceProfilesManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setResourceProfilesManager(ResourceProfilesManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setResourceProfilesManager(ResourceProfilesManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setResourceRequests(List<ResourceRequestInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setResources(HashMap<String, LocalResourceInfo>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ContainerLaunchContextInfo
 
setResourceSecondsMap(Map<String, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
Set the aggregated number of resources that the application has allocated times the number of seconds the application has been running.
setResourceSecondsMap(Map<String, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setResourceUsage(ResourceUsage) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
setRMApplicationHistoryWriter(RMApplicationHistoryWriter) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setRMApplicationHistoryWriter(RMApplicationHistoryWriter) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setRMApplicationHistoryWriter(RMApplicationHistoryWriter) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
setRMAppLifetimeMonitor(RMAppLifetimeMonitor) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setRMAppLifetimeMonitor(RMAppLifetimeMonitor) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setRMAppLifetimeMonitor(RMAppLifetimeMonitor) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
setRMContext(RMContext) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Set RMContext for ReservationSystem.
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
setRMContext(RMContext) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceScheduler
Set RMContext for ResourceScheduler.
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
setRMDelegatedNodeLabelsUpdater(RMDelegatedNodeLabelsUpdater) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setRMDelegatedNodeLabelsUpdater(RMDelegatedNodeLabelsUpdater) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setRMDelegatedNodeLabelsUpdater(RMDelegatedNodeLabelsUpdater) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setRMDelegationTokenSecretManager(RMDelegationTokenSecretManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setRMDelegationTokenSecretManager(RMDelegationTokenSecretManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setRMDelegationTokenSecretManager(RMDelegationTokenSecretManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setRMDispatcher(Dispatcher) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Dispatcher used to send state operation completion events to ResourceManager services
setRMStateStore(RMStateStore) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
setRMTimelineCollectorManager(RMTimelineCollectorManager) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setRMTimelineCollectorManager(RMTimelineCollectorManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setRMTimelineCollectorManager(RMTimelineCollectorManager) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
setRolledLogsExcludePattern(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
setRolledLogsIncludePattern(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LogAggregationContextInfo
 
setRunningContainers(List<RMContainer>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
setRunningContainers(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setScheduleAynschronously(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setScheduler(ResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setSchedulerRecoveryStartAndWaitTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setSchedulerRecoveryStartAndWaitTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setSchedulingMode(SchedulingMode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setSchedulingPolicy(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setScopeIfNotNull(Set<ApplicationId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
 
setSecrets(HashMap<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CredentialsInfo
 
setServiceContext(RMServiceContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
Note: setting service context clears all services embedded with it.
setShouldFailAutoQueueCreationWhenGuaranteedCapacityExceeded(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setShutdownNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setSize(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
setSizeBasedWeight(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.FairOrderingPolicy
 
setSkippedType(CSAssignment.SkippedType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setStageExecutionInterval(Plan, ReservationDefinition, ReservationRequest, RLESparseResourceAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
setStartTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setStartTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setStartTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setStartTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setStartTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
setStartTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceAllocationInfo
 
setState(RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setState(RMAppState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setState(RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setState(RMAppState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setState(String, QueueState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setState(YarnApplicationState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setState(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppState
 
setStateStore(RMStateStore) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setStateStore(RMStateStore) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setSteadyFairShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setSubmitTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
 
setSubmitTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setSystemClock(Clock) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setSystemClock(Clock) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
setSystemClock(Clock) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setSystemMetricsPublisher(SystemMetricsPublisher) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
setSystemMetricsPublisher(SystemMetricsPublisher) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setSystemMetricsPublisher(SystemMetricsPublisher) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
setTempUserPerPartition(TempUserPerPartition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
setTimeoutType(ApplicationTimeoutType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppTimeoutInfo
 
setTimerForTokenRenewal(DelegationTokenRenewer.DelegationTokenToRenew) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
set task to renew the token
setTimerTask(DelegationTokenRenewer.RenewalTimerTask) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
setTimeStamp(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
setTimestamp(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
setToBePreemptFromOther(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.AbstractPreemptionEntity
 
setToken(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.DelegationToken
 
setTokens(HashMap<String, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CredentialsInfo
 
setToKillContainers(List<RMContainer>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.ContainerAllocation
 
setTotalCapacity(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
setTotalCapacity(Resource) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanEdit
Sets the overall capacity in terms of Resource assigned to this plan.
setTotalCost(double) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
setTotalMB(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setTotalNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setTotalResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
setTotalVirtualCores(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setType(NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setType(LocalResourceType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
setUnhealthyNodes(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
setUnmanagedAM(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationSubmissionContextInfo
 
setUntrackedTimeStamp(long) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
setUntrackedTimeStamp(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setup() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
setupConfigurableCapacities(QueueCapacities) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractAutoCreatedLeafQueue
 
setupConfigurableCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
setupConfigurableCapacities(CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
setupConfigurableCapacities(CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ReservationQueue
 
setupQueueConfigs(Resource, CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
setupQueueConfigs(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setupQueueConfigs(Resource, CapacitySchedulerConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setupQueueConfigs(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
setupSecurityAndFilters(Configuration, RMDelegationTokenSecretManager) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebAppUtil
Helper method to setup filters and authentication for ResourceManager WebServices.
setupTokens(ContainerLaunchContext, ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
setUrl(URI) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
setUsed(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setUsed(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setUsed(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setUsedCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueMetrics
 
setUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setUsedCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
setUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionQueueCapacitiesInfo
 
setUsedResource(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
setUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationStateData
The application submitter
setUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
setUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ReservationInfo
 
setUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
setUserAMLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setUserAMLimit(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ResourceUsage
 
setUserAmLimit(ResourceInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.PartitionResourcesInfo
 
setUserLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
setUserLimit(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setUserLimit(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Set configured user-limit.
setUserLimitFactor(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setUserLimitFactor(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Set configured user-limit factor.
setUserResourceLimit(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
setvCores(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
setVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
setVcoresPerNode(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
setVisibility(LocalResourceVisibility) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.LocalResourceInfo
 
setWeight(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
setWeights(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
Allows setting weight for a dynamically created queue.
setWeights(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
setWorkPreservingRecoveryEnabled(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMActiveServiceContext
 
setWorkPreservingRecoveryEnabled(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setYarnConfiguration(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setYarnConfiguration(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMServiceContext
 
SharingPolicy - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation
This is the interface for policy that validate new ReservationAllocations for allocations being added to a Plan.
shift(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
This method shifts all the timestamp of the Resource entries by the specified "delta".
shouldAppFailFast(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
shouldCancelAtEnd - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
shouldContainersBeAutoUpdated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
shouldCountTowardsMaxAttemptRetry() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Return the flag which indicates whether the attempt failure should be counted to attempt retry count.
shouldCountTowardsMaxAttemptRetry() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
shouldFailAutoCreationWhenGuaranteedCapacityExceeded() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
shouldMoveOnExpiry() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
shouldShowReservationAsQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.ReservationQueueConfiguration
 
showRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Print human-readable requests to LOG debug.
showRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
showRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
showRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
showReservationsAsQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.PlanQueue
Determine whether to hide/show the ReservationQueues
SHUTDOWN_HOOK_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Priority of the ResourceManager shutdown hook.
SIGNAL_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
SignalContainerTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.SignalContainerTransition
 
signalToContainer(SignalContainerRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
Send a signal to a container.
SimpleBlacklistManager - Class in org.apache.hadoop.yarn.server.resourcemanager.blacklist
Maintains a list of failed nodes and returns that as long as number of blacklisted nodes is below a threshold percentage of total nodes.
SimpleBlacklistManager(int, double) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.blacklist.SimpleBlacklistManager
 
SimpleCandidateNodeSet<N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
A simple CandidateNodeSet which keeps an unordered map
SimpleCandidateNodeSet(N) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SimpleCandidateNodeSet
 
SimpleCandidateNodeSet(Map<NodeId, N>, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SimpleCandidateNodeSet
 
SimpleCapacityReplanner - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
This (re)planner scan a period of time from now to a maximum time window (or the end of the last session, whichever comes first) checking the overall capacity is not violated.
SimpleCapacityReplanner() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.SimpleCapacityReplanner
 
SingleConstraintAppPlacementAllocator<N extends SchedulerNode> - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement
This is a simple implementation to do affinity or anti-affinity for inter/intra apps.
SingleConstraintAppPlacementAllocator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
SIZE_BASED_WEIGHT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether to give more weight to apps requiring many resources.
sizeBasedWeight - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
SKIP_AM_ALLOCATION_DUE_TO_LOCALITY - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
SKIP_AM_ALLOCATION_IN_BLACK_LISTED_NODE - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
SKIP_AM_ALLOCATION_IN_IGNORE_EXCLUSIVE_MODE - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
SKIP_ASSIGNMENT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
SKIP_BLACK_LISTED_NODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
SKIP_IN_IGNORE_EXCLUSIVITY_MODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
SKIP_NODE_LOCAL_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
SKIP_OFF_SWITCH_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
SKIP_PRIORITY_BECAUSE_OF_RELAX_LOCALITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
SKIP_RACK_LOCAL_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
skipContainerBasedOnIntraQueuePolicy(FiCaSchedulerApp, Resource, Resource, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
SKIPPED_ALL_PRIORITIES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
SMOOTHNESS_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
sortByDelta(List<ReservationAllocation>, long, Plan) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
Sort in the order from the least new amount of resources asked (likely negative) to the highest.
sortCSConfigurations() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
sortedNodeList(Comparator<N>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ClusterNodeTracker
Convenience method to sort nodes.
sourceName(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
Specified() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.Specified
 
StageAllocator - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
Interface for allocating a single stage in IterativePlanner.
StageAllocatorGreedy - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
Computes the stage allocation according to the greedy allocation rule.
StageAllocatorGreedy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorGreedy
 
StageAllocatorGreedyRLE - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
Computes the stage allocation according to the greedy allocation rule.
StageAllocatorGreedyRLE(boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorGreedyRLE
 
StageAllocatorLowCostAligned - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
A stage allocator that iteratively allocates containers in the StageAllocatorLowCostAligned.DurationInterval with lowest overall cost.
StageAllocatorLowCostAligned(boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
StageAllocatorLowCostAligned(int, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
StageAllocatorLowCostAligned.DurationInterval - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
An inner class that represents an interval, typically of length duration.
StageExecutionInterval - Interface in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
An auxiliary class used to compute the time interval in which the stage can be allocated resources by IterativePlanner.
StageExecutionIntervalByDemand - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
An implementation of StageExecutionInterval, which sets the execution interval of the stage.
StageExecutionIntervalByDemand() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalByDemand
 
StageExecutionIntervalUnconstrained - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
An implementation of StageExecutionInterval which gives each stage the maximal possible time interval, given the job constraints.
StageExecutionIntervalUnconstrained() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalUnconstrained
 
StageProvider(boolean, ReservationDefinition) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner.StageProvider
 
start() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
start() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
start() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
 
START_TIME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
startAll() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
startAppAllocationRecording(ActivitiesManager, NodeId, long, SchedulerApplicationAttempt) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.APP
 
STARTED_TIME_BEGIN - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
STARTED_TIME_END - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
startedOn - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
startedTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
startInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
startInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
startInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
startInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
startInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived classes start themselves using this method.
startInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
startNodeUpdateRecording(ActivitiesManager, NodeId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesLogger.NODE
 
startServer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
startTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
startTimelineCollector() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
Starts the application level timeline collector for this app.
startWepApp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
STATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
state - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
state - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
state - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
state - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
STATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
STATES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
StatisticsItemInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
StatisticsItemInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
StatisticsItemInfo(YarnApplicationState, String, long) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
statItem - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationStatisticsInfo
 
StatusUpdateWhenHealthyTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.StatusUpdateWhenHealthyTransition
 
StatusUpdateWhenUnHealthyTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.StatusUpdateWhenUnHealthyTransition
 
stepRoundDown(long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
stepRoundDown(long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
stepRoundDown(long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalByDemand
 
stepRoundUp(long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
stepRoundUp(long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned
 
stepRoundUp(long, long) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageExecutionIntervalByDemand
 
stop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitorManager
 
stop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
stop(RMAppState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
stop(RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
stop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
stop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
stop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
 
stopQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
stopQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
stopQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueStateManager
Stop the queue.
stopQueue() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueue
Stop the queue.
stopServer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
stopTimelineCollector() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
Stops the application level timeline collector for this app.
storeApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to store the state of an application attempt
storeApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
storeApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to store the state of an application.
storeApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
StoreFencedException - Exception in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
StoreFencedException() - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.recovery.StoreFencedException
 
StoreLimitException - Exception in org.apache.hadoop.yarn.server.resourcemanager.recovery
This exception is thrown when Application Data size exceeds limit RM state store.
StoreLimitException(String) - Constructor for exception org.apache.hadoop.yarn.server.resourcemanager.recovery.StoreLimitException
 
storeNewApplication(RMApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Non-Blocking API ResourceManager services use this to store the application's state This does not block the dispatcher threads RMAppStoredEvent will be sent on completion to notify the RMApp
storeNewApplicationAttempt(RMAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
storeNewMasterKey(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
storeNewReservation(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking Apis to maintain reservation state.
storeNewToken(RMDelegationTokenIdentifier, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
storeOrUpdateAMRMTokenSecretManager(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Store or Update state of AMRMToken Master Key
storeOrUpdateAMRMTokenSecretManagerState(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeOrUpdateAMRMTokenSecretManagerState(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeOrUpdateAMRMTokenSecretManagerState(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeOrUpdateAMRMTokenSecretManagerState(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeOrUpdateAMRMTokenSecretManagerState(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to store or update the state of AMRMToken Master Key
storeOrUpdateAMRMTokenSecretManagerState(AMRMTokenSecretManagerState, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
storeReservationState(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeReservationState(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeReservationState(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeReservationState(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeReservationState(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to store the state of a reservation allocation.
storeReservationState(YarnProtos.ReservationAllocationStateProto, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
storeRMDelegationToken(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
RMDTSecretManager call this to store the state of a delegation token and sequence number
storeRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to store the state of RMDelegationToken and sequence number
storeRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
storeRMDTMasterKey(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
RMDTSecretManager call this to store the state of a master key
storeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to store the state of DelegationToken Master Key
storeRMDTMasterKeyState(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Derived class use this method to store the version information.
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.InMemoryConfigurationStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.LeveldbConfigurationStore
 
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
Persist the hard-coded schema version to the conf store.
storeVersion() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
subClusterHeartbeat(SubClusterHeartbeatRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
submit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
SUBMIT_APP_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
SUBMIT_RESERVATION_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
submitApp(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
submitAppAttempt(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
submitApplication(SubmitApplicationRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
submitApplication(ApplicationSubmissionContext, long, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
submitApplication(ApplicationId, String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Submit a new application to the queue.
submitApplication(ApplicationId, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
submitApplication(ApplicationId, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
submitApplication() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
submitApplication(ApplicationSubmissionContextInfo, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Function to submit an app to the RM.
submitApplication(ApplicationSubmissionContextInfo, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
submitApplicationAttempt(FiCaSchedulerApp, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Submit an application attempt to the queue.
submitApplicationAttempt(FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
submitApplicationAttempt(FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
submitReservation(ReservationSubmissionRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
submitReservation(ReservationSubmissionRequestInfo, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Function to submit a Reservation to the RM.This method is reachable by using RMWSConsts.RESERVATION_SUBMIT.
submitReservation(ReservationSubmissionRequestInfo, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
submitResourceCommitRequest(Resource, CSAssignment) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
subtractSchedulingOpportunity(SchedulerRequestKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
sumOfChildAbsCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
sumOfChildCapacities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
swapContainer(RMContainer, RMContainer, ContainerUpdateType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
Swaps the existing RMContainer's and the temp RMContainers internal container references after adjusting the resources in each.
synchronizePlan(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractReservationSystem
 
synchronizePlan(Plan, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.AbstractSchedulerPlanFollower
 
synchronizePlan(Plan, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanFollower
The function performing the actual synchronization operation for a given Plan.
synchronizePlan(String, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystem
Invokes PlanFollower to synchronize the specified Plan with the ResourceScheduler
SystemMetricsPublisher - Interface in org.apache.hadoop.yarn.server.resourcemanager.metrics
Interface used to publish app/container events to timelineservice.

T

tag(MetricsInfo, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
TargetApplications - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
This class is used by TargetApplicationsNamespace.evaluate(TargetApplications) to evaluate a namespace.
TargetApplications(ApplicationId, Set<ApplicationId>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplications
 
TargetApplications(ApplicationId, Map<ApplicationId, Set<String>>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplications
 
TargetApplicationsNamespace - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Class to describe the namespace of allocation tags, used by AllocationTags.
TargetApplicationsNamespace(AllocationTagNamespaceType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
 
TargetApplicationsNamespace.All - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Namespace to all applications in the cluster.
TargetApplicationsNamespace.AppID - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Namespace defined by a certain application ID.
TargetApplicationsNamespace.AppTag - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Namespace to applications that attached with a certain application tag.
TargetApplicationsNamespace.NotSelf - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Namespace to all applications except itself.
TargetApplicationsNamespace.Self - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint
Namespace within application itself.
TempAppPerPartition - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Temporary data-structure tracking resource availability, pending resource need, current utilization for an application.
tempContainerToKill - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
TempQueuePerPartition - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Temporary data-structure tracking resource availability, pending resource need, current utilization.
TempQueuePerPartition(String, Resource, boolean, String, Resource, float, float, Resource, Resource, CSQueue, Resource, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
TempSchedulerNode - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
This class will save necessary information which copied from FiCaSchedulerNode.
TempSchedulerNode() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempSchedulerNode
 
TempUserPerPartition - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity
Temporary data-structure tracking resource availability, pending resource need, current utilization for an application.
THREAD_JOIN_TIMEOUT_MS - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
THREAD_JOIN_TIMEOUT_MS - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
THREAD_JOIN_TIMEOUT_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AllocationFileLoaderService
 
THROW_ON_VIOLATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.invariants.InvariantsChecker
 
TIME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
TimelinePublishEvent(AbstractSystemMetricsPublisher.SystemMetricsEventType, ApplicationId) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.TimelinePublishEvent
 
TimelineServiceV1Publisher - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
This class is responsible for posting application, appattempt & Container lifecycle related events to timeline service v1.
TimelineServiceV1Publisher() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV1Publisher
 
TimelineServiceV2Publisher - Class in org.apache.hadoop.yarn.server.resourcemanager.metrics
This class is responsible for posting application, appattempt & Container lifecycle related events to timeline service v2.
TimelineServiceV2Publisher(RMTimelineCollectorManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.metrics.TimelineServiceV2Publisher
 
TIMEOUT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
TIMEOUTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
timerTask - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
timeStamp - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ActivitiesInfo
 
timeStamp - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppActivitiesInfo
 
timeStamp - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAllocationInfo
 
toAccessType(QueueACL) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
toAllocations(List<YarnProtos.ResourceAllocationRequestProto>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
toByteArray() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.RMDelegationTokenIdentifierData
 
toCumulativeString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
toGlobalString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
toInMemoryAllocation(String, ReservationId, YarnProtos.ReservationAllocationStateProto, Resource, ResourceCalculator) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
toIntervalMap() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
Returns the representation of the current resources allocated over time as an interval map (in the defined non-null range).
token - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
toReservationId(YarnProtos.ReservationIdProto) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
toResource(ReservationRequest) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
toResources(Map<ReservationInterval, ReservationRequest>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationSystemUtil
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempAppPerPartition
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
toString() - Method in enum org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping.MappingType
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.Epoch
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationStateDataPBImpl
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryReservationAllocation
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.PeriodicRLESparseResourceAllocation
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.StageAllocatorLowCostAligned.DurationInterval
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInterval
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppToMonitor
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.AllocationExpirationInfo
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMFatalEvent
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage.UsageByLabel
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityNode
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueCapacities
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ContainerAllocationProposal
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.PendingAsk
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceCommitRequest
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.SchedulerContainer
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.PlacedSchedulingRequest
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.api.SchedulingRequestWithPlacementAttempt
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.AppID
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace.AppTag
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.TargetApplicationsNamespace
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.ContainerPreemptEvent
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Convenient toString implementation for debugging.
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.PendingAskUpdateResult
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedContainerChangeRequest
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagInfo
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AllocationTagsInfo
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
toString() - Method in enum org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields.DeSelectType
use literals as toString.
TOTAL_PREEMPTION_PER_ROUND - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
Maximum percentage of resources preemptionCandidates in a single round.
totalNodeCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
trackingUI - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
trackingUrl - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
trackingUrlIsNotReady - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
trackingUrlPretty - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
trackNonRunnableApp(FSAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Tracks the given new non runnable app so that it can be made runnable when it would not violate max running app limits.
trackRunnableApp(FSAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Tracks the given new runnable app for purposes of maintaining max running app limits.
transferStateFromAttempt(RMAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
transferStateFromPreviousAppSchedulingInfo(AppSchedulingInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
transferStateFromPreviousAttempt(SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
transferStateFromPreviousAttempt(SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
transformToTree() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
transition(RMAppAttemptImpl, RMAppAttemptEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl.ScheduleTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.AddContainersToBeRemovedFromNMTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.AddNodeTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.CleanUpAppTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.CleanUpContainerTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.DeactivateNodeTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.DecommissioningNodeTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.RecommissionNodeTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.ReconnectNodeTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.SignalContainerTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.StatusUpdateWhenHealthyTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.StatusUpdateWhenUnHealthyTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.UpdateContainersTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.UpdateNodeResourceWhenRunningTransition
 
transition(RMNodeImpl, RMNodeEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.UpdateNodeResourceWhenUnusableTransition
 
transitionToActive(HAServiceProtocol.StateChangeRequestInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
transitionToStandby(HAServiceProtocol.StateChangeRequestInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
triggerUpdate() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Allows UpdateThread to start processing without waiting till AbstractYarnScheduler.updateInterval.
trimQueueName(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerUtilities
 
tryCommit(Resource, ResourceCommitRequest, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
tryCommit(Resource, ResourceCommitRequest, boolean) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.ResourceAllocationCommitter
Try to commit the allocation Proposal.
TryManyReservationAgents - Class in org.apache.hadoop.yarn.server.resourcemanager.reservation.planning
A planning algorithm that invokes several other planning algorithms according to a given order.
TryManyReservationAgents(List<ReservationAgent>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.TryManyReservationAgents
 
tryPreemptContainerAndDeductResToObtain(ResourceCalculator, CapacitySchedulerPreemptionContext, Map<String, Resource>, RMContainer, Resource, Map<ApplicationAttemptId, Set<RMContainer>>, Map<ApplicationAttemptId, Set<RMContainer>>, Resource, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.CapacitySchedulerPreemptionUtils
Invoke this method to preempt container based on resToObtain.
turnOnAppActivitiesRecording(ApplicationId, double) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivitiesManager
 
type - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
TYPE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
TypeToCountedTags() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.AllocationTagsManager.TypeToCountedTags
 

U

UI2_WEBAPP_NAME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
UNAUTHORIZED_USER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
uncaughtException(Thread, Throwable) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMCriticalThreadUncaughtExceptionHandler
 
UNDEFINED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
UNDEFINED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerUpdateContext
 
unmanagedApplication - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
UNREGISTER_AM - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
unregisterApp(ApplicationId, ApplicationTimeoutType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
unregisterApp(ApplicationId, Set<ApplicationTimeoutType>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
unregisterApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.MemoryPlacementConstraintManager
 
unregisterApplication(ApplicationId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Remove the constraints that correspond to a given application.
unRegisterApplication(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
unregisterApplicationAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
unregisterAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
unRegisterNodeManager(UnRegisterNodeManagerRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
 
unreserve(SchedulerRequestKey, FiCaSchedulerNode, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
unreserve(SchedulerRequestKey, FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
Remove the reservation on node at the given SchedulerRequestKey.
UNRESERVED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
unreserveResource(SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
unreserveResource(SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
unreserveResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
unreserveResource(String, String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
unreserveResource(SchedulerApplicationAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Unreserve resources on this node.
untrackNonRunnableApp(FSAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Stops tracking the given non-runnable app
untrackRunnableApp(FSAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Updates the relevant tracking variables after a runnable app with the given queue and user has been removed.
update(RMNode, NodeStatus) - Method in class org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher
Update rmNode decommissioning status based on NodeStatus.
update() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Update internal state of the scheduler.
update() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Recompute the internal variables used by the scheduler - per-job weights, fair shares, deficits, minimum slot allocations, and amount of used and required resources per job.
update(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Set the queue's fairshare and update the demand/fairshare of child queues/applications.
UPDATE_APP_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
UPDATE_APP_TIMEOUTS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
UPDATE_INTERVAL_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
The update interval for calculating resources in FairScheduler .
UPDATE_OUTSTANDING_ERROR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
UPDATE_RESERVATION_REQUEST - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
updateAggregateAppResourceUsage(Resource, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
updateAggregateAppResourceUsage(Map<String, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
updateAggregatePreemptedAppResourceUsage(Resource, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
updateAggregatePreemptedAppResourceUsage(Map<String, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
updateAllocation(long, NodeId, ContainerId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateAllocationConfiguration(AllocationConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
updateAMContainerDiagnostics(SchedulerApplicationAttempt.AMState, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateAMLaunchDiagnostics(String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
To capture Launch diagnostics of the app.
updateAMLaunchDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
updateAndCheckCapacitiesByLabel(String, QueueCapacities, QueueCapacities) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
This method intends to be used by ReservationQueue, ReservationQueue will not appear in configuration file, so we shouldn't do load capacities settings in configuration for reservation queue.
updateAppContainerStateAndTime(ContainerId, ActivityState, long, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AppAllocation
 
updateApplicationAttemptState(ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
updateApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
updateApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
updateApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
updateApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
updateApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
updateApplicationAttemptStateInternal(ApplicationAttemptId, ApplicationAttemptStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
updateApplicationHomeSubCluster(UpdateApplicationHomeSubClusterRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.federation.FederationStateStoreService
 
updateApplicationPriority(UpdateApplicationPriorityRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
updateApplicationPriority(UserGroupInformation, ApplicationId, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
updateApplicationPriority will invoke scheduler api to update the new priority to RM and StateStore.
updateApplicationPriority(Priority, ApplicationId, SettableFuture<Object>, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
updateApplicationPriority(Priority, ApplicationId, SettableFuture<Object>, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
updateApplicationPriority(SchedulerApplication<FiCaSchedulerApp>, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
updateApplicationPriority(Priority, ApplicationId, SettableFuture<Object>, UserGroupInformation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Change application priority of a submitted application at runtime
updateApplicationPriority(AppPriority, HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method updates the priority for a specific application, and it is reachable by using RMWSConsts.APPS_APPID_PRIORITY.
updateApplicationPriority(AppPriority, HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
updateApplicationState(ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
updateApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
updateApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
updateApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
updateApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
updateApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
updateApplicationStateInternal(ApplicationId, ApplicationStateData) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
updateApplicationStateSynchronously(ApplicationStateData, boolean, SettableFuture<Object>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
updateApplicationTimeout(Map<ApplicationTimeoutType, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
updateApplicationTimeout(RMApp, Map<ApplicationTimeoutType, String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
updateApplicationTimeout(AppTimeoutInfo, HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method updates the timeout information for a specific app, and it is reachable by using RMWSConsts.APPS_TIMEOUT.
updateApplicationTimeout(AppTimeoutInfo, HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
updateApplicationTimeouts(UpdateApplicationTimeoutsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
updateApplicationTimeouts(ApplicationId, Map<ApplicationTimeoutType, Long>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.monitor.RMAppLifetimeMonitor
 
updateAppQueue(AppQueue, HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method updates the queue for a specific application, and it is reachable by using RMWSConsts.APPS_APPID_QUEUE.
updateAppQueue(AppQueue, HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
updateAppSkipNodeDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
Set the message temporarily if the reason is known for why scheduling did not happen for a given node, if not message will be over written
updateAppState(AppState, HttpServletRequest, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
This method updates the state of the app in input, and it is reachable by using RMWSConsts.APPS_APPID_STATE.
updateAppState(AppState, HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
updateBlacklist(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateClusterResource(Resource, ResourceLimits) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Update the cluster resource for queues as we add/remove nodes
updateClusterResource(Resource, ResourceLimits) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
updateClusterResource(Resource, ResourceLimits) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
updateConfigurableResourceRequirement(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
updateContainerErrors - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateContainerState(ContainerId, AllocationState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.NodeAllocation
 
UpdateContainersTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.UpdateContainersTransition
 
updateContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
UPDATED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
UpdatedContainerInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
UpdatedContainerInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.UpdatedContainerInfo
 
UpdatedContainerInfo(List<ContainerStatus>, List<ContainerStatus>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.UpdatedContainerInfo
 
updateDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSAppAttempt
 
updateDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
updateDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
updateDemand() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Refresh the Schedulable's demand and those of its children if any.
updatedNMTokens - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateDynamicResourceConfiguration(DynamicResourceConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
Update DynamicResourceConfiguration with new configuration.
updateFencedState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
updateFile(Path, byte[], boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
updateInterval - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
To enable the update thread, subclasses should set updateInterval to a positive value during AbstractYarnScheduler.serviceInit(Configuration).
updateKeepAliveApplications(List<ApplicationId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
Add a list of applications to the keep alive list.
updateKillableContainerResource(KillableContainer, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.preemption.PreemptionManager
 
updateLabels(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Update the labels for the node.
updateMetrics(ApplicationId, NodeType, SchedulerNode, Container, String, Queue) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
updateNMTokens(Collection<Container>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateNode(RMNode) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.ClusterMonitor
 
updateNode(RMNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
updateNodeInfoForAMDiagnostics(FiCaSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
updateNodeLabels(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMDelegatedNodeLabelsUpdater
Update node labels for a specified node.
updateNodeResource(UpdateNodeResourceRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
updateNodeResource(RMNode, ResourceOption) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.ClusterMonitor
 
updateNodeResource(NodeId, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.RMNodeLabelsManager
 
updateNodeResource(RMNode, ResourceOption) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Process resource update on a node.
updateNodeResource(RMNode, ResourceOption) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor
 
updateNodeResource(RMNode, ResourceOption) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Process resource update on a node and update Queue.
updateNodeResourceUtilization(RMNode, SchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Update container and utilization information on the NodeManager.
UpdateNodeResourceWhenRunningTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.UpdateNodeResourceWhenRunningTransition
 
UpdateNodeResourceWhenUnusableTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.UpdateNodeResourceWhenUnusableTransition
 
updatePendingAsk(Collection<ResourceRequest>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Replace existing pending asks by the new requests
updatePendingAsk(SchedulerRequestKey, SchedulingRequest, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.AppPlacementAllocator
Replace existing pending asks by the new SchedulingRequest
updatePendingAsk(Collection<ResourceRequest>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
updatePendingAsk(SchedulerRequestKey, SchedulingRequest, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.LocalityAppPlacementAllocator
 
updatePendingAsk(Collection<ResourceRequest>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
updatePendingAsk(SchedulerRequestKey, SchedulingRequest, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.placement.SingleConstraintAppPlacementAllocator
 
updatePlacesBlacklistedByApp(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
The ApplicationMaster is updating the placesBlacklistedByApp used for containers other than AMs.
updatePlacesBlacklistedBySystem(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
Update the list of places that are blacklisted by the system.
updatePreemptableExtras(ResourceCalculator) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempQueuePerPartition
 
updatePreemptedMemoryMBSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
updatePreemptedVcoreSeconds(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
updatePreemption(long, NodeId, ContainerId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updatePreemptionInfo(Resource, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptMetrics
 
updatePreemptionQuotaForULDeltaAsDone(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.TempUserPerPartition
 
UpdateQueue(CSQueue, QueueState, AutoCreatedLeafQueueConfig) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange.UpdateQueue
 
UpdateQueue(CSQueue, AutoCreatedLeafQueueConfig) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange.UpdateQueue
 
updateQueueState(QueueState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
updateQueueState(QueueState) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerQueue
Update the queue state.
updateQueueStatistics(ResourceCalculator, Resource, AbstractCSQueue, RMNodeLabelsManager, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
Update Queue Statistics:
updateRelease(long, NodeId, ContainerId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateReservation(ReservationUpdateRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
updateReservation(ReservationAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.InMemoryPlan
 
updateReservation(ReservationAllocation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.PlanEdit
Updates an existing ReservationAllocation in the plan.
updateReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.AlignedPlannerWithGreedy
 
updateReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.GreedyReservationAgent
 
updateReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.PlanningAlgorithm
 
updateReservation(ReservationId, String, Plan, ReservationDefinition) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.ReservationAgent
Update a reservation for the user that abides by the specified contract
updateReservation(ReservationId, String, Plan, ReservationDefinition) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.TryManyReservationAgents
 
updateReservation(long, NodeId, ContainerId, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateReservation(ReservationUpdateRequestInfo, HttpServletRequest) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServiceProtocol
Function to update a Reservation to the RM.
updateReservation(ReservationUpdateRequestInfo, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
updateResourceForReleasedContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
updateResourceForReleasedContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Update the resources of the node when releasing a container.
updateResourceRequests(List<ResourceRequest>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
The ApplicationMaster is updating resource requirements for the application, by asking for more resources and releasing resources acquired by the application.
updateResourceRequests(Map<SchedulerRequestKey, Map<String, ResourceRequest>>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
The ApplicationMaster is updating resource requirements for the application, by asking for more resources and releasing resources acquired by the application.
updateResourceRequests(List<ResourceRequest>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateRMDelegationToken(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
RMDTSecretManager call this to update the state of a delegation token and sequence number
updateRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
updateRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.LeveldbRMStateStore
 
updateRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
updateRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
updateRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
Blocking API Derived classes must implement this method to update the state of RMDelegationToken and sequence number
updateRMDelegationTokenState(RMDelegationTokenIdentifier, Long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
updateRules(List<PlacementRule>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.placement.PlacementManager
 
updateRunnabilityOnAppRemoval(FSAppAttempt, FSLeafQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
Checks to see whether any other applications runnable now that the given application has been removed from the given queue.
updateRunnabilityOnReload() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.MaxRunningAppsEnforcer
This is called after reloading the allocation configuration when the scheduler is reinitilized Checks to see whether any non-runnable applications become runnable now that the max running apps of given queue has been changed Runs in O(n) where n is the number of apps that are non-runnable and in the queues that went from having no slack to having slack.
updateSchedulerAllocationCounts(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulerConfiguration(SchedConfUpdateInfo, HttpServletRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
updateSchedulerFulfilledReservationCounts(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulerHealthInformation(Resource, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
Update schedulerHealth information.
updateSchedulerPreemptionCounts(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulerReleaseCounts(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulerReleaseDetails(long, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulerReservationCounts(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulerRunDetails(long, Resource, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerHealth
 
updateSchedulingRequests(List<SchedulingRequest>, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
The ApplicationMaster is updating resource requirements for the application, by asking for more resources and releasing resources acquired by the application.
updateSchedulingRequests(List<SchedulingRequest>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
updateSchedulingResourceUsage(ResourceUsage) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.policy.AbstractComparatorOrderingPolicy
 
updateStoredToken(RMDelegationTokenIdentifier, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
updateTotalResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Set total resources on the node.
updateUsageRatio(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Update new usage ratio.
updateUsageRatio(ResourceCalculator, Resource, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
updateUsedCapacity(ResourceCalculator, Resource, String, AbstractCSQueue) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueueUtils
Update partitioned resource usage, if nodePartition == null, will update used resource for all partitions of this queue.
updateUserResourceUsage(String, Resource, String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
During container allocate/release, ensure that all user specific data structures are updated.
updateUserWeights() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
 
UsageByLabel() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage.UsageByLabel
 
usages - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
usedAMResource - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
usedCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
usedCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
usedCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
usedMemoryMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
usedNodeCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
usedResource - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
usedVirtualCores - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
User(String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager.User
 
User() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueuePlacementRule.User
 
user - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
user - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
user - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.RMQueueAclInfo
 
USER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWSConsts
 
USER_AM_RESOURCE_LIMIT_EXCEED - Static variable in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAMContainerLaunchDiagnosticsConstants
 
USER_AS_DEFAULT_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether to use the user name as the queue name (instead of "default") if the request does not specify a queue.
USER_CAPACITY_MAXIMUM_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityDiagnosticConstant
 
USER_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
USER_LIMIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
USER_LIMIT_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
USER_SETTINGS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
USER_WEIGHT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
userAMResourceLimit - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
UserGroupMappingPlacementRule - Class in org.apache.hadoop.yarn.server.resourcemanager.placement
 
UserGroupMappingPlacementRule(boolean, List<UserGroupMappingPlacementRule.QueueMapping>, Groups) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule
 
UserGroupMappingPlacementRule.QueueMapping - Class in org.apache.hadoop.yarn.server.resourcemanager.placement
 
UserGroupMappingPlacementRule.QueueMapping.MappingType - Enum in org.apache.hadoop.yarn.server.resourcemanager.placement
 
UserInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
userLimit - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
userLimitFactor - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
userLimitNeedsRecompute() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
Force UsersManager to recompute userlimit.
userMetricsAvailable - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
UserMetricsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
UserMetricsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
UserMetricsInfo(ResourceManager, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
username - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
userResourceLimit - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
users - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
users - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
UsersInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
UsersInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UsersInfo
 
UsersInfo(ArrayList<UserInfo>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UsersInfo
 
usersList - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UsersInfo
 
UsersManager - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
UsersManager tracks users in the system and its respective data structures.
UsersManager(QueueMetrics, LeafQueue, RMNodeLabelsManager, CapacitySchedulerContext, ResourceCalculator) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UsersManager
UsersManager Constructor.
UsersManager.User - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
User class stores all user related resource usage, application details.

V

validate(Plan, ReservationAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.CapacityOverTimePolicy
The validation algorithm walks over the RLE encoded allocation and checks that for all transition points (when the start or end of the checking window encounters a value in the RLE).
validate(Plan, ReservationAllocation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.NoOverCommitPolicy
 
validate(Plan, ReservationAllocation) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.reservation.SharingPolicy
This method runs the policy validation logic, and return true/false on whether the ReservationAllocation is acceptable according to this sharing policy.
validate(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
validateAndApplyQueueManagementChanges(List<QueueManagementChange>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
Asynchronously called from scheduler to apply queue management changes
validateAndSplitUpdateResourceRequests(RMContext, AllocateRequest, Resource, List<UpdateContainerError>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Check if we have: - Request for same containerId and different target resource.
validateApplicationTimeouts(Map<ApplicationTimeoutType, Long>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
validateBlacklistRequest(ResourceBlacklistRequest) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
validateConfigs(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
validateConfigurations(AutoCreatedLeafQueueConfig) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AutoCreatedLeafQueue
 
validateConstraint(Set<String>, PlacementConstraint) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManager
Validate a placement constraint and the set of allocation tags that will enable it.
validateConstraint(Set<String>, PlacementConstraint) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManagerService
 
validateContainerReleaseRequest(List<ContainerId>, ApplicationAttemptId) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
It will validate to make sure all the containers belong to correct application attempt id.
validateISO8601AndConvertToLocalTimeEpoch(Map<ApplicationTimeoutType, String>) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Validate ISO8601 format with epoch time.
validateOrderNoGap(RLESparseResourceAllocation, Map<ReservationInterval, Resource>, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.planning.IterativePlanner
 
validateOutSameAppPriorityFromDemand(Resource, TreeSet<TempAppPerPartition>, Map<String, TempUserPerPartition>, ProportionalCapacityPreemptionPolicy.IntraQueuePreemptionOrderPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.FifoIntraQueuePreemptionPlugin
 
validateQueueEntitlementChange(AbstractAutoCreatedLeafQueue, QueueEntitlement) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractManagedParentQueue
 
validateQueueManagementChanges(List<QueueManagementChange>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ManagedParentQueue
 
validateReservationDeleteRequest(ReservationSystem, ReservationDeleteRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInputValidator
Quick validation on the input to check some obvious fail conditions (fail fast) the input and returns the appropriate Plan associated with the specified Queue or throws an exception message illustrating the details of any validation check failures
validateReservationListRequest(ReservationSystem, ReservationListRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInputValidator
Quick validation on the input to check some obvious fail conditions (fail fast) the input and returns the appropriate Plan associated with the specified Queue or throws an exception message illustrating the details of any validation check failures.
validateReservationSubmissionRequest(ReservationSystem, ReservationSubmissionRequest, ReservationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInputValidator
Quick validation on the input to check some obvious fail conditions (fail fast) the input and returns the appropriate Plan associated with the specified Queue or throws an exception message illustrating the details of any validation check failures
validateReservationUpdateRequest(ReservationSystem, ReservationUpdateRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.reservation.ReservationInputValidator
Quick validation on the input to check some obvious fail conditions (fail fast) the input and returns the appropriate Plan associated with the specified Queue or throws an exception message illustrating the details of any validation check failures
validateSourceTags(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.PlacementConstraintManagerService
Validates whether the allocation tags that will enable a constraint have the expected format.
validateSubmitApplication(ApplicationId, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
validateSubmitApplication(ApplicationId, String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Validate submitApplication api so that moveApplication do a pre-check.
validateSubmitApplication(ApplicationId, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
validateSubmitApplication(ApplicationId, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingHistoryEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncherEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher.DecommissioningNodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.SystemMetricsEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy.IntraQueuePreemptionOrderPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.NodesListManagerEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping.MappingType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMStateStoreState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation.RLEOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent.RMAppNodeUpdateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.RMAppManagerEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.RMFatalEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AllocationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue.CapacityConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.AllocationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser.AppPriorityACLKeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration.AbsoluteResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment.SkippedType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange.QueueAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.SchedulingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests.IteratorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor.LoadComparator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.SchedulerEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt.AMState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields.DeSelectType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingHistoryEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncherEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.DecommissioningNodesWatcher.DecommissioningNodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.metrics.AbstractSystemMetricsPublisher.SystemMetricsEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy.IntraQueuePreemptionOrderPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.NodesListManagerEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.placement.UserGroupMappingPlacementRule.QueueMapping.MappingType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMStateStoreState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.reservation.RLESparseResourceAllocation.RLEOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent.RMAppNodeUpdateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.RMAppManagerEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.RMFatalEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage.ResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.ActivityState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.activities.AllocationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue.CapacityConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.allocator.AllocationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AppPriorityACLConfigurationParser.AppPriorityACLKeyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration.AbsoluteResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment.SkippedType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.QueueManagementChange.QueueAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.SchedulingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.AssignmentInformation.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.constraint.processor.BatchedRequests.IteratorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.distributed.NodeQueueLoadMonitor.LoadComparator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.SchedulerEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt.AMState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.hadoop.yarn.server.resourcemanager.webapp.DeSelectFields.DeSelectType
Returns an array containing the constants of this enum type, in the order they are declared.
VCORES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.DynamicResourceConfiguration
 
verifyAdminAccess(YarnAuthorizationProvider, String, Log) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
 
verifyAdminAccess(YarnAuthorizationProvider, String, String, Log) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.RMServerUtils
Utility method to verify if the current user has access based on the passed AccessControlList
verifyAndSetPolicyFromConf(AllocationConfiguration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Recursively check policies for queues in pre-order.
verifyCentralizedNodeLabelConfEnabled(String, boolean) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.nodelabels.NodeLabelsUtils
 
version - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
VERSION_NODE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 

W

WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
WAIT_TIME_BEFORE_NEXT_STARVATION_CHECK_MS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Configurable delay (ms) before an app's starvation is considered after it is identified.
webAppAddress - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
weights - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
withApplicationTags(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withApplicationTypes(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withFinishTimeBegin(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withFinishTimeEnd(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withLimit(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withQueueQuery(ResourceManager, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withStartedTimeBegin(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withStartedTimeEnd(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withStateQuery(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withStatesQuery(Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
withUserQuery(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.ApplicationsRequestBuilder
 
writeAuditLog(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
writeFile(Path, byte[], boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
writeLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceProfilesManagerImpl
 
writeLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
writeLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractYarnScheduler
 
writeLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.AbstractCSQueue
 
writeLock - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplicationAttempt
 
WritingApplicationAttemptFinishEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingApplicationAttemptFinishEvent(ApplicationAttemptId, ApplicationAttemptFinishData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptFinishEvent
 
WritingApplicationAttemptStartEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingApplicationAttemptStartEvent(ApplicationAttemptId, ApplicationAttemptStartData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationAttemptStartEvent
 
WritingApplicationFinishEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingApplicationFinishEvent(ApplicationId, ApplicationFinishData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationFinishEvent
 
WritingApplicationHistoryEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingApplicationHistoryEvent(WritingHistoryEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationHistoryEvent
 
WritingApplicationStartEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingApplicationStartEvent(ApplicationId, ApplicationStartData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingApplicationStartEvent
 
WritingContainerFinishEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingContainerFinishEvent(ContainerId, ContainerFinishData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerFinishEvent
 
WritingContainerStartEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.ahs
 
WritingContainerStartEvent(ContainerId, ContainerStartData) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ahs.WritingContainerStartEvent
 
WritingHistoryEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.ahs
 

Y

YarnConfigurationStore - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
YarnConfigurationStore exposes the methods needed for retrieving and persisting CapacityScheduler configuration via key-value using write-ahead logging.
YarnConfigurationStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.YarnConfigurationStore
 
YarnConfigurationStoreFactory - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
Factory class for creating instances of YarnConfigurationStore.
YarnScheduler - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
This interface is used by the components to talk to the scheduler for allocating of resources, cleaning up resources.

Z

ZERO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.PendingAsk
 
ZKConfigurationStore - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf
A Zookeeper-based implementation of YarnConfigurationStore.
ZKConfigurationStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
zkManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.conf.ZKConfigurationStore
 
ZKRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
RMStateStore implementation backed by ZooKeeper.
ZKRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 
znodeWorkingPath - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore
 

_

_dec(String, AbstractResourceUsage.ResourceType, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
_get(String, AbstractResourceUsage.ResourceType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
_getAll(AbstractResourceUsage.ResourceType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
_inc(String, AbstractResourceUsage.ResourceType, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
_set(String, AbstractResourceUsage.ResourceType, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AbstractResourceUsage
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 
Skip navigation links

Copyright © 2008–2018 Apache Software Foundation. All rights reserved.