A C D E F G H I J K L M N O P Q R S T U V W Y

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
 
activateApp(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
activateApplication(String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
An application has new outstanding requests.
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
activeNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
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
 
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(NodeInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodesInfo
 
addApp(FSSchedulerApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
addApplication(ApplicationAttemptId, String, String) - 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, Credentials, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
Add application tokens for renewal.
addChildQueue(FSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
addPersistedPassword(Token<AMRMTokenIdentifier>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Populate persisted password of AMRMToken back to AMRMTokenSecretManager.
addPreemptContainer(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
addPreemption(RMContainer, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
addReReservation(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
addSchedulingOpportunity(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
addToQueueInfoList(CapacitySchedulerQueueInfo) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
adjustWeight(AppSchedulable, double) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.NewAppWeightBooster
 
adjustWeight(AppSchedulable, double) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.WeightAdjuster
 
AdminService - Class in org.apache.hadoop.yarn.server.resourcemanager
 
AdminService(Configuration, ResourceScheduler, RMContext, NodesListManager, ClientRMService, ApplicationMasterService, ResourceTrackerService) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
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 - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Time to wait between checks of the allocation file
ALLOC_RELOAD_WAIT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
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, Priority, ResourceRequest, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
Resources have been allocated to this application by the resource scheduler.
allocate(ApplicationAttemptId, List<ResourceRequest>, List<ContainerId>, List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
allocate(NodeType, FiCaSchedulerNode, Priority, ResourceRequest, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<ContainerId>, List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
allocate(NodeType, FSSchedulerNode, Priority, ResourceRequest, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<ContainerId>, List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
allocate(ApplicationAttemptId, List<ResourceRequest>, List<ContainerId>, List<String>, List<String>) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
The main api between the ApplicationMaster and the Scheduler.
allocateContainer(ApplicationId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
The Scheduler has allocated containers on this node to the given application.
allocateContainer(ApplicationId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
The Scheduler has allocated containers on this node to the given application.
allocatedMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
allocatedMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
allocateResources(String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
Allocation - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
Allocation(List<Container>, Resource) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
Allocation(List<Container>, Resource, Set<ContainerId>) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
Allocation(List<Container>, Resource, Set<ContainerId>, Set<ContainerId>, List<ResourceRequest>) - 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
 
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
 
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
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
 
amRmTokenSecretManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
AMRMTokenSecretManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
AMRM-tokens are per ApplicationAttempt.
AMRMTokenSecretManager(Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Create an AMRMTokenSecretManager
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
 
AppAddedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
AppAddedSchedulerEvent(ApplicationAttemptId, String, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
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(RMAppAttempt, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
AppAttemptsInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
AppAttemptsInfo() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptsInfo
 
AppBlock - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
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(RMApp, Boolean, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
AppInfo(RMApp, Boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
applicationACLsManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ApplicationAttemptStateData - Interface in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
 
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(YarnServerResourceManagerServiceProtos.ApplicationAttemptStateDataProto) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
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.security.DelegationTokenRenewer.DelegationTokenToRenew
 
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
 
applications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
applications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
applications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
ApplicationStateData - Interface in org.apache.hadoop.yarn.server.resourcemanager.recovery.records
Contains all the state data that needs to be stored persistently for an Application
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(YarnServerResourceManagerServiceProtos.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
 
applicationType - 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
 
AppRemovedSchedulerEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.event
 
AppRemovedSchedulerEvent(ApplicationAttemptId, RMAppAttemptState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppRemovedSchedulerEvent
 
AppSchedulable - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
AppSchedulable(FairScheduler, FSSchedulerApp, FSLeafQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
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, ActiveUsersManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
appSchedulingInfo - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
appsCompleted - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
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.ClusterMetricsInfo
 
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.ClusterMetricsInfo
 
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.ClusterMetricsInfo
 
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.ClusterMetricsInfo
 
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.ClusterMetricsInfo
 
appsSubmitted - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
ASSIGN_MULTIPLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether to assign multiple containers in one check-in.
assignContainer(FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
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 class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Assign a container on this node if possible, and return the amount of resources assigned.
assignContainerPreCheck(FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Helper method to check if the queue should attempt assigning resources
assignContainers(Resource, FiCaSchedulerNode) - 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) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
assignContainers(Resource, FiCaSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
assignMultiple - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
assignReservedContainer(FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
attempt - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptsInfo
 
availableMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
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
 

C

cancelDelegationToken(CancelDelegationTokenRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
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
 
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
 
CapacitySchedulerContext - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
Read-only interface to CapacityScheduler context.
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) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerInfo
 
CapacitySchedulerLeafQueueInfo - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp.dao
 
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
 
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, QueueACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.QueueACLsManager
 
checkAppNumCompletedLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
clearQueueMetrics() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Helper method to clear cache - used only for unit tests.
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
 
clientToAMSecretManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
ClientToAMTokenSecretManagerInRM - Class in org.apache.hadoop.yarn.server.resourcemanager.security
 
ClientToAMTokenSecretManagerInRM() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
closeInternal() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
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.
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, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
clusterTimeStamp - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
commonPreHead(Hamlet.HTML<HtmlPage._>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
compare(Priority, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.Priority.Comparator
 
compare(AppSchedulable, AppSchedulable) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FifoAppComparator
 
compare(Schedulable, Schedulable) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
 
COMPLETED_APPLICATION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
completedContainer(Resource, FiCaSchedulerApp, FiCaSchedulerNode, RMContainer, ContainerStatus, RMContainerEventType, CSQueue) - 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) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
completedContainer(Resource, FiCaSchedulerApp, FiCaSchedulerNode, RMContainer, ContainerStatus, RMContainerEventType, CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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
 
computeShares(Collection<? extends Schedulable>, Resource, ResourceType) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.ComputeFairShares
Given a set of Schedulables and a number of slots, compute their weighted fair shares.
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 at schedule time.
conf - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
CONTAINER_RESERVED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
ContainerAllocationExpirer - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
 
ContainerAllocationExpirer(Dispatcher) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.ContainerAllocationExpirer
 
containerCompleted(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
containerCompleted(RMContainer, ContainerStatus, RMContainerEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
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
 
containerId - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
containerLaunchedOnNode(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
ContainerPreemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Simple event class used to communicate containers unreservations, preemption, killing
ContainerPreemptEvent(ApplicationAttemptId, RMContainer, ContainerPreemptEventType) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerPreemptEvent
 
ContainerPreemptEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
containersAllocated - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
containersPending - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
containersReserved - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
containerTokenSecretManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AboutPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.AppPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
content() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
context - Variable in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
count - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
create(int) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.resource.Priority
 
createAbnormalContainerStatus(ContainerId, String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility to create a ContainerStatus during exceptional circumstances.
createAdminService(ClientRMService, ApplicationMasterService, ResourceTrackerService) - 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) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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
 
createAndGetNMTokens(String, ApplicationAttemptId, List<Container>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
createApplicationMasterService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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
 
createClientRMService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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
 
createContainer(FSSchedulerApp, FSSchedulerNode, Resource, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
Create and return a container object reflecting an allocation for the given appliction on the given node with the given capability and priority.
createContainerToken(ContainerId, NodeId, String, Resource) - 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.ResourceManager
 
createDelegationTokenRenewer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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
 
createMasterKey(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.ClientToAMTokenSecretManagerInRM
 
createNMTokenSecretManager(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createPassword(AMRMTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Create a password for a given AMRMTokenIdentifier.
createPolicyMonitors() - 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.
createQueueACLsManager(ResourceScheduler, Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createResourceTrackerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRMAppManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRMDelegationTokenSecretManager(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createRunnableLauncher(RMAppAttempt, AMLauncherEventType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.ApplicationMasterLauncher
 
createScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
createSchedulerEventDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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(boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
CSQueue - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
CSQueue represents a node in the tree of hierarchical queues in the CapacityScheduler.
currentConsumption - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
currentReservation - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 

D

deactivateApp(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
deactivateApplication(String, ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
An application has no more outstanding requests.
decommissionedNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
decrActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
decrDecommisionedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
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
 
decrNumUnhealthyNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
decrPendingResources(String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
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_ASSIGN_MULTIPLE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_ENABLE_USER_METRICS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
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_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_LOCALITY_DELAY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
DEFAULT_PREEMPTION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_PREEMPTION_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_RESOURCE_CALCULATOR_CLASS - 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
 
DEFAULT_RM_SCHEDULER_INCREMENT_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
DEFAULT_SIZE_BASED_WEIGHT - 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_WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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
DelegationTokenRenewer.DelegationTokenToRenew(ApplicationId, Token<?>, Configuration, long, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
DEPTH_ANY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
DEPTH_INTERMEDIATE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
DEPTH_LEAF - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
DEPTH_PARENT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
DEPTH_ROOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
diagnostics - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
dispatcher - Variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
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
 
DominantResourceFairnessPolicy.DominantResourceFairnessComparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
 
doSecureLogin() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
DOT - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
dropContainerReservation(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
dropContainerReservation(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.

E

editSchedule() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
editSchedule() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
This method is invoked at regular intervals.
elapsedTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
ENABLE_USER_METRICS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
equals(Object) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
EVENT_LOG_DIR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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(ContainerId) - 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

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(RMContext, ResourceManager, View.ViewContext) - 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
 
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
 
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
 
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, ActiveUsersManager, RMContext) - 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) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
FiCaSchedulerUtils - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica
 
FiCaSchedulerUtils() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerUtils
 
FifoAppComparator - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Order AppSchedulable 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
 
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
 
FileSystemRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
FileSystemRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
finalStatus - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
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
 
finishApp(AppSchedulingInfo, RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
finishApplication(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
finishApplication(FiCaSchedulerApp, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
An application submitted to this queue has finished.
finishApplication(FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
finishApplication(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
 
finishedTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
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.fair.FSQueueMetrics
 
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
 
fs - Variable in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
FSLeafQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSLeafQueue(String, QueueManager, FairScheduler, FSParentQueue) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
FSParentQueue - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSParentQueue(String, QueueManager, 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, QueueManager, 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
 
FSSchedulerApp - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
Represents an application attempt from the viewpoint of the Fair Scheduler.
FSSchedulerApp(ApplicationAttemptId, String, Queue, ActiveUsersManager, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
FSSchedulerNode - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
FSSchedulerNode(RMNode, boolean) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 

G

get() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
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.LeafQueue
 
getAbsoluteCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getAbsoluteCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getAbsoluteMaxCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
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.LeafQueue
 
getAbsoluteMaximumCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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.LeafQueue
 
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getAbsoluteUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
getAcl(String, QueueACL) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getAcls(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getActiveApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getActiveNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getActiveUsersManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the ActiveUsersManager for the queue.
getActiveUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getActiveUsersManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getAddedRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeAddedSchedulerEvent
 
getAllMasterKeys() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getAllocatedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAllocatedMB() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
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
 
getAllocatedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAllocatedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
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.
getAllocationFile() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Path to XML file containing allocations.
getAllowedLocalityLevel(Priority, int, double, double) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
Return the level at which we are allowed to schedule containers, given the current size of the cluster and thresholds indicating how many nodes to fail at (as a fraction of cluster size) before relaxing scheduling constraints.
getAllowUndeclaredPools() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getAllResourceRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getAllTokens() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getAMContainerLogs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
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
 
getAMLivelinessMonitor() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAMLivelinessMonitor() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getAMRMToken() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
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
 
getAMRMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getAMRMTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getAMRMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getApp() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
getApp(HttpServletRequest, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppAttempt() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncherEvent
 
getAppAttemptCredentials() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationAttemptState
 
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
 
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(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 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 interface 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
 
getAppFairShare(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
 
getAppId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationState
 
getAppId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeCleanAppEvent
 
getAppId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.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
 
getApplicableDepth() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
getApplicableDepth() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FairSharePolicy
 
getApplicableDepth() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.FifoPolicy
 
getApplicableDepth() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Specifies the depths in the hierarchy, this SchedulingPolicy applies to
getApplication() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getApplicationACLsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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.AppAddedSchedulerEvent
 
getApplicationAttemptID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppRemovedSchedulerEvent
 
getApplicationAttemptId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
Get ApplicationAttemptId of the application master.
getApplicationComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getApplicationComparator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
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.SchedulerApplication
 
getApplicationId() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getApplicationMasterService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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.
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
 
getApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Obtain (read-only) collection of active applications.
getApplicationState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
getApplicationSubmissionContext() - Method in interface 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 class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationState
 
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
 
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
 
getApps() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppsInfo
 
getApps(HttpServletRequest, String, Set<String>, String, String, String, String, String, String, String, String, Set<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getAppSchedulable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
getAppSchedulables() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
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
 
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
 
getAppsTableColumnDefs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
getAppsTableColumnDefs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
getAppState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAppEvent
 
getAppState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreRemoveAppEvent
 
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
 
getAppWeight(AppSchedulable) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getAssignMultiple() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationState
 
getAttemptCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationState
 
getAttemptId() - Method in interface 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.recovery.RMStateStore.ApplicationAttemptState
 
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
 
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.scheduler.common.fica.FiCaSchedulerNode
 
getAvailableResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getAvailableResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get available resources on the node.
getAvailableResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNodeReport
 
getAvailableVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getAvailNodeCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getBindAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
getBindAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getCapacity(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
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.LeafQueue
 
getCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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
 
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 class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
 
getClientRMService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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 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.fair.FairScheduler
 
getClusterCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
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 class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getClusterMetrics(GetClusterMetricsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getClusterMetricsInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getClusterNodes(GetClusterNodesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
getClusterResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getClusterResources() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
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
 
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.
getCompletedAppsListSize() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
getCompletedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.UpdatedContainerInfo
 
getCompletedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeResponse
 
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
 
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
 
getContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerAcquiredEvent
 
getContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerAllocatedEvent
 
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.ContainerPreemptEvent
 
getContainerAllocationExpirer() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getContainerAllocationExpirer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
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.event.ContainerExpiredSchedulerEvent
 
getContainerMgrProxy(ContainerId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
getContainerPreemptions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getContainerPreemptionTime(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
getContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getContainersAllocated() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getContainerStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerFinishedEvent
 
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
 
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(Class<?>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.JAXBContextResolver
 
getCount() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 
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
 
getCurrentConsumption() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getCurrentReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
Get total current reservations.
getDecommissionedNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getDefault() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
getDelegationToken(GetDelegationTokenRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
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
 
getDemand() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
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 class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Maximum number of resources required by this Schedulable.
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptUnregistrationEvent
 
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.RMAppFailedAttemptEvent
 
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppFinishedAttemptEvent
 
getDiagnostics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
getDispatcher() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getDispatcher() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getDTSequenceNumber() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
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
 
getEventLog() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getEventlogDir() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getExcessReservation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getFairShare() - Method in class 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.
getFairSharePreemptionTimeout() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get the fair share preemption, in milliseconds.
getFairShareVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
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.AppRemovedSchedulerEvent
 
getFinalStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getFinishedApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.NodeResponse
 
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 class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getGroupsForUser(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
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
 
getHeadroom() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
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
 
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.common.fica.FiCaSchedulerNode
 
getHttpAddress() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
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
 
getInactiveRMNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getInactiveRMNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
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
 
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
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
 
getKeepAliveAppIds() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
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
 
getLastNodeHeartBeatResponse() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNode
 
getLastNodeHeartBeatResponse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
getLastTimeAtHalfFairShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getLastTimeAtMinShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getLatestDTSequenceNumber() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
getLatestResponse() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
getLeafQueue(String, boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a queue by name, creating it if the create param is true and is necessary.
getLeafQueues() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a collection of all leaf queues
getLiveContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
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
getLiveNodeManagers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMNMInfo
Implements getLiveNodeManagers()
getLiveNodeManagers() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMNMInfoBeans
 
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(Priority, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getLocalityWaitFactor(Priority, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
getLogsLink() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
getLostNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getMasterContainer() - Method in interface 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 class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationAttemptState
 
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
 
getMaxActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getMaxActiveApplicationsPerUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getMaxAMResourcePerQueuePercent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Used only by tests.
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
 
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
 
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
 
getMaxAssign() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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
 
getMaximumActiveApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getMaximumActiveApplicationsPerUser() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Used only by tests.
getMaximumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
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.LeafQueue
 
getMaximumCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getMaximumResourceCapability() - 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() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getMaximumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getMaximumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get maximum allocatable Resource.
getMaximumSystemApplications() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMaxQueueMemoryCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getMaxResources(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get the maximum resource allocation for the given queue.
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.
getMaxShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
getMaxShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMaxShare() - Method in class 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
 
getMemory() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
getMessage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptLaunchFailedEvent
 
getMessage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptRejectedEvent
 
getMessage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRejectedEvent
 
getMetrics() - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getMetrics() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
Get metrics reference from containing queue.
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
 
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
getMinimumAllocation() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
Used only by tests.
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.
getMinimumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getMinimumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getMinimumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getMinimumResourceCapability() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getMinimumResourceCapability() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get minimum allocatable Resource.
getMinQueueMemoryCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getMinResources(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get the minimum resource allocation for the given queue.
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.AppSchedulable
 
getMinShare() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getMinShare() - Method in class 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
 
getMinShareMemoryFraction() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerQueueInfo
Returns the queue's min share in as a fraction of the entire cluster capacity.
getMinSharePreemptionTimeout(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get a queue's min share preemption timeout, in milliseconds.
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 interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
 
getMonitorInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
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.fair.AppSchedulable
 
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 class 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
 
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.SchedulerApplication
 
getNewlyLaunchedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.UpdatedContainerInfo
 
getNextKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
 
getNextKey() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager
 
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(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
 
getNodeHealthStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
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 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.common.fica.FiCaSchedulerNode
 
getNodeID() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
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.NodeInfo
 
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
 
getNodeLocalityThreshold() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getNodeName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getNodeName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getNodeName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get the name of the node for scheduling matching decisions.
getNodeReport(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getNodeReport(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getNodeReport(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
getNodeReport(NodeId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get node resource usage report.
getNodes(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
Returns all nodes in the cluster.
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
 
getNumActiveNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ActiveUsersManager
Get number of active users i.e.
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(String) - 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.LeafQueue
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getNumContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
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
 
getNumDecommisionedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumLostNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
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
 
getNumRebootedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getNumReservedContainers(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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
 
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.capacity.LeafQueue
 
getParent() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getPendingContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
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
 
getPendingVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getPolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getPolicyName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
getPolicyName() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
 
getPreemptionContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
getPreemptionEnabled() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getPreemptionInterval() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getPriorities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getPriorities() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Job priority for jobs in FIFO queues; meaningless for QueueSchedulables.
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
 
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
 
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() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.AppAddedSchedulerEvent
 
getQueue(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Gets a queue by name.
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
getQueueAcl(String, QueueACL) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Get the ACLs associated with this queue.
getQueueACLsManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getQueueComparator() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getQueueComparator() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerContext
 
getQueueInfo(GetQueueInfoRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
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
 
getQueueInfoList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfoList
 
getQueueManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
getQueueMaxApps(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
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.capacity.LeafQueue
 
getQueueName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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.SchedulerApplication
 
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
 
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.scheduler.capacity.LeafQueue
 
getQueuePath() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
getQueuePath() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
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.fair.QueueManager
Get a collection of all 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
 
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
 
getQueueWeight(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getRack() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
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.common.fica.FiCaSchedulerNode
 
getRackName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getRackName() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get rackname.
getRanNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttempt
Nodes on which the containers for this RMAppAttempt ran.
getRanNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
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
 
getRemoteContainerStatus() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerFinishedEvent
 
getRemovedException() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRemovedEvent
 
getRemovedRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeRemovedSchedulerEvent
 
getReReservations(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getReservedAppSchedulable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getReservedContainer() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getReservedContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
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.ClusterMetricsInfo
 
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.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
 
getReservedPriority() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainer
 
getReservedPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
getReservedPriority() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerReservedEvent
 
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
 
getReservedVirtualCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getResource(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getResource(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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
 
getResourceLimit() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getResourcePreemptions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
getResourceRequest(Priority, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getResourceRequest(Priority, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getResourceRequests(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
getResourceRequests(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getResourceScheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
return the scheduler.
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
 
getResourceTrackerService() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
return the resource tracking component.
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
getResourceUsage() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Get the aggregate amount of resources consumed by the schedulable.
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
 
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.SchedulerApplication
 
getRMContainerTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getRMContext() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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
 
getRMDelegationTokenSecretManager() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMDelegationTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getRMDTSecretManagerState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
getRMNMTokenSecretManager() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
getRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.event.NodeUpdateSchedulerEvent
 
getRMNode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getRMNodes() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getRMNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
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
 
getRootQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
getRootQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getRootQueueInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FairSchedulerInfo
 
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.
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
 
getRunnable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
Is this application runnable? Runnable means that the user and queue application counts are within configured quotas.
getRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getRunningContainers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
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.capacity.CapacityScheduler
 
getSchedulerAppInfo(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.fifo.FifoScheduler
 
getSchedulerAppInfo(ApplicationAttemptId) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.YarnScheduler
Get the Scheduler app for a given app attempt Id.
getSchedulerInfo() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
getSchedulingOpportunities(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
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.webapp.dao.FairSchedulerQueueInfo
Returns the name of the scheduling policy used by this queue.
getServices() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.authorize.RMPolicyProvider
 
getSizeBasedWeight() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
getSkipped() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
getStartedOn() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterInfo
 
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.AppSchedulable
 
getStartTime() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getStartTime() - Method in class 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
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
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(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 class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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.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 interface org.apache.hadoop.yarn.server.resourcemanager.RMContext
 
getStateStore() - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
getStatItems() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ApplicationStatisticsInfo
 
getStore(Configuration) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreFactory
 
getStoredException() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptStoredEvent
 
getStoredException() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppStoredEvent
 
getStrictContainerPreemptions() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.Allocation
 
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 interface 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 class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationState
 
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
 
getTokenState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
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
 
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
 
getTotalPendingRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
getTotalRequiredResources(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
getTotalResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getTotalResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getTotalResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get total resources on the node.
getTotalResourcePending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
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 class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptUnregistrationEvent
 
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
 
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.StatisticsItemInfo
 
getUnhealthyNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
getUnhealthyNodes() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
getUnusableNodes(Collection<RMNode>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
Provides the currently unusable nodes.
getUpdateType() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppNodeUpdateEvent
 
getUsedCapacity() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the current used capacity of the queue and it's children (if any).
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUsedCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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
 
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.
getUsedNodeCapacity() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNode
Get used resources on the node.
getUsedResource() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerNodeReport
 
getUsedResources() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Get the currently utilized resources in the cluster by the queue and children (if any).
getUsedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUsedResources() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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
 
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 interface 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.recovery.RMStateStore.ApplicationState
 
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() - 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.webapp.dao.AppInfo
 
getUserAsDefaultQueue() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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.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.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUserMaxApps(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
getUserMetrics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
getUsername() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.UserInfo
 
getUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
getUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
getUsersList() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UsersInfo
 
getvCores() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ResourceInfo
 
getWaitTimeBeforeKill() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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(ResourceType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
getWeights() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
getWeights() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
getWeights() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Job/queue weight in fair sharing.

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(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(ContainerPreemptEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.RMContainerPreemptEventDispatcher
 
handle(SchedulerEvent) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.SchedulerEventDispatcher
 
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
 
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.capacity.LeafQueue
 
hasAccess(QueueACL, UserGroupInformation) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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
 
hasContainerForNode(Priority, FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
Whether this app has containers requests that could be satisfied on the given node, if the node had full space.
hashCode() - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
healthReport - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 

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
 
id - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
incrActiveUsers() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
incrAppsRunning(AppSchedulingInfo, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
incrDecommisionedNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
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
 
incrNumUnhealthyNMs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClusterMetrics
 
incrPendingResources(String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Increment pending resource metrics
index() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
init(Configuration, EventHandler<ContainerPreemptEvent>, PreemptableResourceScheduler) - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
init(Configuration, EventHandler<ContainerPreemptEvent>, PreemptableResourceScheduler) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingEditPolicy
 
initialize(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy
 
initialize() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
initialize(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
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.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.
invokePolicy() - Method in class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
isApplicableTo(SchedulingPolicy, byte) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
Checks if the specified SchedulingPolicy can be used for a queue at the specified depth in the hierarchy
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
 
isAppSafeToUnregister() - Method in interface org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMApp
Check whether this application is safe to unregister.
isAppSafeToUnregister() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
isBlacklisted(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
isBlacklisted(FiCaSchedulerApp, FiCaSchedulerNode, Log) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerUtils
 
isBlacklisted(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
isBlacklisted(SchedulerApplication, SchedulerNode, Log) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppUtils
 
isPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
isPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
Is this application pending?
isPending() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerAppReport
Is this application pending?
isReserved(SchedulerNode, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
Has the application reserved the given node at the given priority?
isStopped - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
isStopped() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
isTrackingUrlReady() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
isValidNode(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 

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
 
killContainer(RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
killContainer(RMContainer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.PreemptableResourceScheduler
Ask the scheduler to forcibly interrupt the container given as input

L

lastHealthUpdate - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
lastPreemptionUpdateTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
lastScheduledContainer - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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
 
liveContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
loadState() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
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
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.
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.RMStateStore
 
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
 
logFailure(String, String, String, String, String, ApplicationId, ContainerId) - 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) - 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.
logsLink - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
logSuccess(String, String, String, ApplicationId, ContainerId) - 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, 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) - 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
 
lostNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 

M

main(String[]) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
masterService - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
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.
MAX_IGNORED_OVER_CAPACITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Maximum amount of resources above the target capacity ignored for preemption.
maxActiveApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
maxActiveApplicationsPerUser - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
maxApplications - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerLeafQueueInfo
 
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
 
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_SYSTEM_APPLICATIONS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
maxQueueMemoryCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
MemoryRMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
MemoryRMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
metricsAvailable() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
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.
MINIMUM_CAPACITY_VALUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
minQueueMemoryCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
MONITORING_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Time in milliseconds between invocations of this policy

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.AppInfo
 
NATURAL_TERMINATION_FACTOR - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Given a computed preemption target, account for containers naturally expiring and preempt only this percentage of the delta.
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
 
NEUTRAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
newApplicationAttemptStateData(ApplicationAttemptId, Container, ByteBuffer) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
NewAppWeightBooster - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
A WeightAdjuster implementation that gives a weight boost to new jobs for a certain amount of time -- by default, a 3x weight boost for 60 seconds.
NewAppWeightBooster() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.NewAppWeightBooster
 
newlyAllocatedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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
 
nmTokenSecretManager - 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 - 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
 
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.AppAttemptInfo
 
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
 
nodeLocalityThreshold - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
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
 
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() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
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
 
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
 
NodeType - Enum in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Resource classification.
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
 
NONE_ACL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
normalizeRequest(ResourceRequest, 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 minMemory and is not zero.
normalizeRequest(ResourceRequest, ResourceCalculator, Resource, 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 minMemory and is not zero.
normalizeRequests(List<ResourceRequest>, ResourceCalculator, Resource, Resource, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility method to normalize a list of resource requests, by insuring that the memory for each request is a multiple of minMemory and is not zero.
normalizeRequests(List<ResourceRequest>, ResourceCalculator, Resource, Resource, Resource, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility method to normalize a list of resource requests, by insuring that the memory for each request is a multiple of minMemory and is not zero.
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
 
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

OBSERVE_ONLY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
If true, run the policy but do not affect the cluster with preemption and kill events.
org.apache.hadoop.yarn.server.resourcemanager - package org.apache.hadoop.yarn.server.resourcemanager
 
org.apache.hadoop.yarn.server.resourcemanager.amlauncher - package org.apache.hadoop.yarn.server.resourcemanager.amlauncher
 
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.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.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.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.capacity - package org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity
 
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.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.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.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.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
 

P

parent - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
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.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".
pendingContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
pendingMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
policy - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
postHead(Hamlet.HTML<HtmlPage._>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.FairSchedulerPage
 
PreemptableResourceScheduler - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Interface for a scheduler that supports preemption/killing
preemptContainer(ApplicationAttemptId, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
preemptContainer(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
PREEMPTED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
PREEMPTION - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Whether preemption is enabled.
PREEMPTION_INTERVAL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
preemptionEnabled - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
preemptionInterval - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
preemptResources(Collection<FSLeafQueue>, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Preempt a quantity of resources from a list of QueueSchedulables.
preemptTasksIfNecessary() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Check for queues that need tasks preempted, either because they have been below their guaranteed share for minSharePreemptionTimeout or they have been below half their fair share for the fairSharePreemptionTimeout.
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.AppPage
 
preHead(Hamlet.HTML<HtmlPage._>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmView
 
Priority - Class in org.apache.hadoop.yarn.server.resourcemanager.resource
 
Priority() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.Priority
 
Priority.Comparator - Class in org.apache.hadoop.yarn.server.resourcemanager.resource
 
Priority.Comparator() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.Priority.Comparator
 
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(Configuration, EventHandler<ContainerPreemptEvent>, CapacityScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
ProportionalCapacityPreemptionPolicy(Configuration, EventHandler<ContainerPreemptEvent>, CapacityScheduler, Clock) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
 
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.SchedulerApplication
 
pullRMNodeUpdates(Collection<RMNode>) - 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(Collection<RMNode>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 

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 - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
 
queue - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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_INFO - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
queueACLsManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
QueueACLsManager - Class in org.apache.hadoop.yarn.server.resourcemanager.security
 
QueueACLsManager(ResourceScheduler, Configuration) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.QueueACLsManager
 
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
 
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
 
queueMetrics - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Simple metrics cache to help prevent re-registrations.
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
 
queuePath - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.CapacitySchedulerQueueInfo
 
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
 

R

rack - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
rackLocalityThreshold - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
rebootedNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
recomputeShares() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
recomputeShares() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
recomputeShares() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
Recomputes the shares for all child queues and applications based on this queue's current share
recordFactory - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
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.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.RMDelegationTokenSecretManager
 
Recoverable - Interface in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
recoverContainer(Resource, FiCaSchedulerApp, Container) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Recover the state of the queue
recoverContainer(Resource, FiCaSchedulerApp, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
recoverContainer(Resource, FiCaSchedulerApp, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
refreshAdminAcls(RefreshAdminAclsRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshNodes(RefreshNodesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
refreshNodes(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.NodesListManager
 
refreshQueues(RefreshQueuesRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
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_AM - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
registerAppAttempt(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ApplicationMasterService
 
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
 
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
 
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) - 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.ParentQueue
 
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.
RELEASE_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
releaseContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
Release an allocated container on this node.
releaseContainer(Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
Release an allocated container on this node.
RELEASED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
releaseResources(String, int, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
reloadAllocs() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Updates the allocation list from the allocation config file.
reloadAllocsIfNecessary() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
Reload allocations file if it hasn't been loaded in a while
removeApp(FSSchedulerApp) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
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(RMStateStore.ApplicationState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
removeApplication(FiCaSchedulerApp, LeafQueue.User) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
removeApplication(FiCaSchedulerApp, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
removeApplicationState(RMStateStore.ApplicationState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
removeApplicationState(RMStateStore.ApplicationState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
removeApplicationState(RMStateStore.ApplicationState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
removeApplicationState(RMStateStore.ApplicationState) - 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
removeNodeKey(NodeId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM
This is to be called when NodeManager reconnects or goes down.
removeRMDelegationToken(RMDelegationTokenIdentifier, int) - 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.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
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.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
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
 
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.AppBlock
 
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
 
renewDelegationToken(RenewDelegationTokenRequest) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
renewIfServiceIsStarted(List<DelegationTokenRenewer.DelegationTokenToRenew>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
renewToken(DelegationTokenRenewer.DelegationTokenToRenew) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
reserve(SchedulerNode, Priority, RMContainer, Container) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
reservedContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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.ClusterMetricsInfo
 
reservedMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 
reserveResource(SchedulerApplication, Priority, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
reserveResource(FSSchedulerApp, Priority, RMContainer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
reserveResource(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
resetAllowedLocalityLevel(Priority, NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
Should be called when the scheduler assigns a container at a higher degree of locality than the current threshold.
resetReReservations(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
resetSchedulingOpportunities(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
Should be called when an application has successfully scheduled a container, or when the scheduling locality threshold is relaxed.
resetSchedulingOpportunities(Priority, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
resolve(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceTrackerService
resolving the network topology.
RESOURCE_CALCULATOR_CLASS - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
ResourceComparator for scheduling.
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
 
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.ApplicationAttemptEventDispatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.ApplicationAttemptEventDispatcher
 
ResourceManager.ApplicationEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.ApplicationEventDispatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.ApplicationEventDispatcher
 
ResourceManager.NodeEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.NodeEventDispatcher(RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.NodeEventDispatcher
 
ResourceManager.RMContainerPreemptEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.RMContainerPreemptEventDispatcher(PreemptableResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.RMContainerPreemptEventDispatcher
 
ResourceManager.SchedulerEventDispatcher - Class in org.apache.hadoop.yarn.server.resourcemanager
 
ResourceManager.SchedulerEventDispatcher(ResourceScheduler) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.SchedulerEventDispatcher
 
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
 
ResourceScheduler - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler
This interface is the one implemented by the schedulers.
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
 
ResourceType - Enum in org.apache.hadoop.yarn.server.resourcemanager.resource
 
ResourceWeights - Class in org.apache.hadoop.yarn.server.resourcemanager.resource
 
ResourceWeights(float, float) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
ResourceWeights(float) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
ResourceWeights() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
resToPreempt(FSLeafQueue, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
Return the resource amount that this queue is allowed to preempt, if any.
retrievePassword(AMRMTokenIdentifier) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
Retrieve the password for the given AMRMTokenIdentifier.
RM_SCHEDULER_INCREMENT_ALLOCATION_MB - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
Increment request grant-able by the RM scheduler.
RM_SCHEDULER_INCREMENT_ALLOCATION_VCORES - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
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.
RMAppAttemptContainerAcquiredEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptContainerAcquiredEvent(ApplicationAttemptId, Container) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerAcquiredEvent
 
RMAppAttemptContainerAllocatedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptContainerAllocatedEvent(ApplicationAttemptId, Container) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptContainerAllocatedEvent
 
RMAppAttemptContainerFinishedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptContainerFinishedEvent(ApplicationAttemptId, ContainerStatus) - 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
 
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, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
RMAppAttemptLaunchFailedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptLaunchFailedEvent(ApplicationAttemptId, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptLaunchFailedEvent
 
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
 
RMAppAttemptRejectedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptRejectedEvent(ApplicationAttemptId, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptRejectedEvent
 
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
 
RMAppAttemptStoredEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event
 
RMAppAttemptStoredEvent(ApplicationAttemptId, Exception) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.event.RMAppAttemptStoredEvent
 
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
 
RMAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppEvent(ApplicationId, RMAppEventType) - 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) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppFailedAttemptEvent
 
RMAppFinishedAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppFinishedAttemptEvent(ApplicationId, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppFinishedAttemptEvent
 
RMAppImpl - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppImpl(ApplicationId, RMContext, Configuration, String, String, String, ApplicationSubmissionContext, YarnScheduler, ApplicationMasterService, long, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppImpl
 
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
 
RMAppManagerEventType - Enum in org.apache.hadoop.yarn.server.resourcemanager
 
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
 
RMAppRejectedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppRejectedEvent(ApplicationId, String) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRejectedEvent
 
RMAppRemovedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppRemovedEvent(ApplicationId, Exception) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppRemovedEvent
 
RMAppState - Enum in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppStoredEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmapp
 
RMAppStoredEvent(ApplicationId, Exception) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmapp.RMAppStoredEvent
 
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.AuditConstants - Class in org.apache.hadoop.yarn.server.resourcemanager
 
RMAuditLogger.AuditConstants() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
RMContainer - Interface in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
Represents the ResourceManager's view of an application container.
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, ApplicationAttemptId, NodeId, EventHandler, ContainerAllocationExpirer) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
RMContainerReservedEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmcontainer
The event signifying that a container has been reserved.
RMContainerReservedEvent(ContainerId, Resource, NodeId, Priority) - 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
 
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
RMContext - Interface in org.apache.hadoop.yarn.server.resourcemanager
Context of the ResourceManager.
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
rmContext - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
RMContextImpl - Class in org.apache.hadoop.yarn.server.resourcemanager
 
RMContextImpl(Dispatcher, RMStateStore, ContainerAllocationExpirer, AMLivelinessMonitor, AMLivelinessMonitor, DelegationTokenRenewer, AMRMTokenSecretManager, RMContainerTokenSecretManager, NMTokenSecretManagerInRM, ClientToAMTokenSecretManagerInRM) - 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
 
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
 
rmDTSecretManager - Variable in class org.apache.hadoop.yarn.server.resourcemanager.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
 
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
 
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) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
RMNodeImpl.AddNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.AddNodeTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.AddNodeTransition
 
RMNodeImpl.CleanUpAppTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.CleanUpAppTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.CleanUpAppTransition
 
RMNodeImpl.CleanUpContainerTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.CleanUpContainerTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.CleanUpContainerTransition
 
RMNodeImpl.DeactivateNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.DeactivateNodeTransition(NodeState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.DeactivateNodeTransition
 
RMNodeImpl.ReconnectNodeTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.ReconnectNodeTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.ReconnectNodeTransition
 
RMNodeImpl.StatusUpdateWhenHealthyTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.StatusUpdateWhenHealthyTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.StatusUpdateWhenHealthyTransition
 
RMNodeImpl.StatusUpdateWhenUnHealthyTransition - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeImpl.StatusUpdateWhenUnHealthyTransition() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl.StatusUpdateWhenUnHealthyTransition
 
RMNodeReconnectEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeReconnectEvent(NodeId, RMNode) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeReconnectEvent
 
RMNodeStatusEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.rmnode
 
RMNodeStatusEvent(NodeId, NodeHealthStatus, List<ContainerStatus>, List<ApplicationId>, NodeHeartbeatResponse) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeStatusEvent
 
RMPolicyProvider - Class in org.apache.hadoop.yarn.server.resourcemanager.security.authorize
PolicyProvider for YARN ResourceManager protocols.
RMPolicyProvider() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.security.authorize.RMPolicyProvider
 
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
 
RMStateStore - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStore() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
RMStateStore.ApplicationAttemptState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
State of an application attempt
RMStateStore.ApplicationAttemptState(ApplicationAttemptId, Container, Credentials) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.ApplicationAttemptState
 
RMStateStore.ApplicationState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
State of an application application
RMStateStore.RMDTSecretManagerState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStore.RMDTSecretManagerState() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMDTSecretManagerState
 
RMStateStore.RMState - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
State of the ResourceManager
RMStateStore.RMState() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.RMState
 
RMStateStoreAppAttemptEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreAppAttemptEvent(RMStateStore.ApplicationAttemptState) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStoreAppAttemptEvent
 
RMStateStoreAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
RMStateStoreAppEvent(RMStateStore.ApplicationState) - 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
 
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
 
RMStateStoreRemoveAppEvent - Class in org.apache.hadoop.yarn.server.resourcemanager.recovery
 
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
 
RMWebServices - Class in org.apache.hadoop.yarn.server.resourcemanager.webapp
 
RMWebServices(ResourceManager, ApplicationACLsManager, QueueACLsManager) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebServices
 
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_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler
 
ROOT_QUEUE - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.QueueManager
 
run() - Method in class org.apache.hadoop.yarn.server.resourcemanager.amlauncher.AMLauncher
 
runningContainers - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.UserMetricsInfo
 

S

Schedulable - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
A Schedulable represents an entity that can launch tasks, such as a job or a queue.
Schedulable() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
 
scheduler - Variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
 
scheduler() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RmController
 
SchedulerApplication - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents an application attempt from the viewpoint of the scheduler.
SchedulerApplication(ApplicationAttemptId, String, Queue, ActiveUsersManager, RMContext) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
SchedulerAppReport - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents an application attempt, and the resources that the attempt is using.
SchedulerAppReport(SchedulerApplication) - 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
 
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
 
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 - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.SchedulerTypeInfo
 
SchedulerNode - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler
Represents a YARN Cluster Node from the viewpoint of the scheduler.
SchedulerNode() - 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
 
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
 
SchedulingEditPolicy - Interface in org.apache.hadoop.yarn.server.resourcemanager.monitor
 
SchedulingMonitor - Class in org.apache.hadoop.yarn.server.resourcemanager.monitor
 
SchedulingMonitor(SchedulingEditPolicy) - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.monitor.SchedulingMonitor
 
SchedulingPolicy - Class in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
 
SchedulingPolicy() - Constructor for class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
SCHEME - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.AdminService
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.ClientRMService
 
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.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.ResourceManager.SchedulerEventDispatcher
 
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.rmcontainer.ContainerAllocationExpirer
 
serviceInit(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
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.monitor.SchedulingMonitor
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
serviceStart() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.SchedulerEventDispatcher
 
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.security.DelegationTokenRenewer
 
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.monitor.SchedulingMonitor
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
serviceStop() - Method in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.SchedulerEventDispatcher
 
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.security.DelegationTokenRenewer
 
setAbsoluteUsedCapacity(float) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Set absolute used capacity of the queue.
setAbsoluteUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setAbsoluteUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
setAcl(String, QueueACL, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAcls(String, Map<QueueACL, AccessControlList>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setAppAttemptTokens(ByteBuffer) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.recovery.records.ApplicationAttemptStateData
 
setAppAttemptTokens(ByteBuffer) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.records.impl.pb.ApplicationAttemptStateDataPBImpl
 
setApplicationSubmissionContext(ApplicationSubmissionContext) - Method in interface 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
 
setAppSchedulable(AppSchedulable) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
setAttemptId(ApplicationAttemptId) - Method in interface 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
 
setAvailableResourcesToQueue(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Set available resources.
setAvailableResourcesToUser(String, Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
Set available resources.
setCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
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.fair.FairScheduler
 
setClusterCapacity(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.policies.DominantResourceFairnessPolicy.DominantResourceFairnessComparator
 
setCompletedAppsMax(int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
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.fair.NewAppWeightBooster
 
setConf(Configuration) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler
 
setDefault(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.SchedulingPolicy
 
setDiagnostics(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmapp.attempt.RMAppAttemptImpl
 
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 class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Assign a fair share to this Schedulable.
setHeadroom(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
setHealthReport(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setLastHealthReportTime(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setLastTimeAtHalfFairShare(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
setLastTimeAtMinShare(long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
setMasterContainer(Container) - Method in interface 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
 
setMasterKey(SecretKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.AMRMTokenSecretManager
 
setMaximumCapacity(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setMaxShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setMinShare(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueueMetrics
 
setNextHeartBeat(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
setNodeHTTPAddress(String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.NodeInfo
 
setParent(CSQueue) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Set the parent Queue.
setParent(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setParent(CSQueue) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
setPolicy(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSLeafQueue
 
setPolicy(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSParentQueue
 
setPolicy(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
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
 
setQueues(String, String[]) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setResourceComparator(Class<? extends ResourceCalculator>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setRMContext(RMContext) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
 
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
 
setRunnable(boolean) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
 
setStateStore(RMStateStore) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMContextImpl
 
setSubmitTime(long) - Method in interface 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
 
setTimerForTokenRenewal(DelegationTokenRenewer.DelegationTokenToRenew) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
set task to renew the token
setTimerTask(TimerTask) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
setType(NodeType) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSAssignment
 
setup() - Method in class org.apache.hadoop.yarn.server.resourcemanager.webapp.RMWebApp
 
setUsedCapacity(float) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Set used capacity of the queue.
setUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
setUsedCapacity(float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
setUser(String) - Method in interface 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
 
setUserLimit(String, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setUserLimitFactor(String, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
setWeight(ResourceType, float) - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
shouldCancelAtEnd - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
showRequests() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
SHUTDOWN_HOOK_PRIORITY - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.ResourceManager
Priority of the ResourceManager shutdown hook.
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
 
sourceName(String) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
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
 
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.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.
startTime - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppAttemptInfo
 
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.AppInfo
 
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
 
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
 
stop(RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
 
stop(RMAppAttemptState) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
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
 
storeApplication(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
storeApplicationAttempt(RMAppAttempt) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore
 
storeApplicationAttemptState(String, ApplicationAttemptStateDataPBImpl) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeApplicationAttemptState(String, ApplicationAttemptStateDataPBImpl) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeApplicationAttemptState(String, ApplicationAttemptStateDataPBImpl) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeApplicationAttemptState(String, ApplicationAttemptStateDataPBImpl) - 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
storeApplicationState(String, ApplicationStateDataPBImpl) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeApplicationState(String, ApplicationStateDataPBImpl) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeApplicationState(String, ApplicationStateDataPBImpl) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeApplicationState(String, ApplicationStateDataPBImpl) - 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.
storeNewMasterKey(DelegationKey) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
storeNewToken(RMDelegationTokenIdentifier, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
storeRMDelegationTokenAndSequenceNumber(RMDelegationTokenIdentifier, Long, int) - 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
storeRMDelegationTokenAndSequenceNumberState(RMDelegationTokenIdentifier, Long, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.FileSystemRMStateStore
 
storeRMDelegationTokenAndSequenceNumberState(RMDelegationTokenIdentifier, Long, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.MemoryRMStateStore
 
storeRMDelegationTokenAndSequenceNumberState(RMDelegationTokenIdentifier, Long, int) - Method in class org.apache.hadoop.yarn.server.resourcemanager.recovery.NullRMStateStore
 
storeRMDelegationTokenAndSequenceNumberState(RMDelegationTokenIdentifier, Long, int) - 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
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.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
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
 
submitApp(String, int) - 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, boolean, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 
submitApplication(FiCaSchedulerApp, String, String) - Method in interface org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CSQueue
Submit a new application to the queue.
submitApplication(FiCaSchedulerApp, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
submitApplication(FiCaSchedulerApp, String, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
subtractSchedulingOpportunity(Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 

T

tag(MetricsInfo, String) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.QueueMetrics
 
throwPolicyDoesnotApplyException(SchedulingPolicy) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSQueue
 
timerTask - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
token - Variable in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer.DelegationTokenToRenew
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.resource.ResourceWeights
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmcontainer.RMContainerImpl
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
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.common.fica.FiCaSchedulerNode
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.ContainerPreemptEvent
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerNode
 
toString() - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Convenient toString implementation for debugging.
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.ResourceInfo
 
TOTAL_PREEMPTION_PER_ROUND - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Maximum percentage of resources preempted in a single round.
totalMB - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
totalNodeCapacity - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.FifoSchedulerInfo
 
totalNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
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
 
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.ReconnectNodeTransition
 
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
 
type - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.StatisticsItemInfo
 

U

UNAUTHORIZED_USER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.RMAuditLogger.AuditConstants
 
UNDEFINED - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacitySchedulerConfiguration
 
unhealthyNodes - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.ClusterMetricsInfo
 
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
 
unreserve(FiCaSchedulerNode, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerApp
 
unreserve(Priority, FSSchedulerNode) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.AppSchedulable
Remove the reservation on node at the given Priority.
unreserve(FSSchedulerNode, Priority) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FSSchedulerApp
 
UNRESERVED_CONTAINER - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
 
unreserveResource(SchedulerApplication) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.common.fica.FiCaSchedulerNode
 
unreserveResource(FSSchedulerApp) - 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
 
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_INTERVAL - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
updateBlacklist(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.AppSchedulingInfo
The ApplicationMaster is updating the blacklist
updateBlacklist(List<String>, List<String>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerApplication
 
updateClusterResource(Resource) - 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) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.LeafQueue
 
updateClusterResource(Resource) - Method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.ParentQueue
 
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.AppSchedulable
 
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 class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.Schedulable
Refresh the Schedulable's demand and those of its children if any.
updateKeepAliveApplications(List<ApplicationId>) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.DelegationTokenRenewer
Add a list of applications to the keep alive list.
updateNodeHeartbeatResponseForCleanup(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.
updateNodeHeartbeatResponseForCleanup(NodeHeartbeatResponse) - Method in class org.apache.hadoop.yarn.server.resourcemanager.rmnode.RMNodeImpl
 
updateResourceRequests(List<ResourceRequest>) - 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.SchedulerApplication
 
updateStoredToken(RMDelegationTokenIdentifier, long) - Method in class org.apache.hadoop.yarn.server.resourcemanager.security.RMDelegationTokenSecretManager
 
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
 
user - Variable in class org.apache.hadoop.yarn.server.resourcemanager.webapp.dao.AppInfo
 
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_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
 
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
 
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, RMContext, 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
 
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
 

V

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
 
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.
validateResourceRequest(ResourceRequest, Resource) - Static method in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.SchedulerUtils
Utility method to validate a resource request, by insuring that the requested memory/vcore is non-negative and not greater than max
validateResourceRequests(List<ResourceRequest>, Resource) - 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
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.NodesListManagerEventType
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.resource.ResourceType
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.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.ContainerPreemptEventType
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.NodeType
Returns the enum constant of this type with the specified name.
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.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.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.resource.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.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.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.ContainerPreemptEventType
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.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.

W

WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.monitor.capacity.ProportionalCapacityPreemptionPolicy
Time in milliseconds between requesting a preemption from an application and killing the container.
WAIT_TIME_BEFORE_KILL - Static variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairSchedulerConfiguration
 
waitTimeBeforeKill - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
weightAdjuster - Variable in class org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair.FairScheduler
 
WeightAdjuster - Interface in org.apache.hadoop.yarn.server.resourcemanager.scheduler.fair
A pluggable object for altering the weights of apps in the fair scheduler, which is used for example by NewAppWeightBooster to give higher weight to new jobs so that short jobs finish faster.
writeAuditLog(ApplicationId) - Method in class org.apache.hadoop.yarn.server.resourcemanager.RMAppManager
 

Y

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.

A C D E F G H I J K L M N O P Q R S T U V W Y

Copyright © 2014 Apache Software Foundation. All Rights Reserved.