Modifier and Type | Class and Description |
---|---|
class |
RMContextImpl |
Modifier and Type | Method and Description |
---|---|
RMContext |
ResourceManager.getRMContext() |
Modifier and Type | Method and Description |
---|---|
protected AMRMTokenSecretManager |
RMSecretManagerService.createAMRMTokenSecretManager(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
protected RMDelegationTokenSecretManager |
RMSecretManagerService.createRMDelegationTokenSecretManager(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
static List<RMNode> |
RMServerUtils.queryRMNodes(RMContext context,
EnumSet<org.apache.hadoop.yarn.api.records.NodeState> acceptedStates) |
Constructor and Description |
---|
AdminService(ResourceManager rm,
RMContext rmContext) |
ApplicationMasterService(RMContext rmContext,
YarnScheduler scheduler) |
ClientRMService(RMContext rmContext,
YarnScheduler scheduler,
RMAppManager rmAppManager,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager applicationACLsManager,
QueueACLsManager queueACLsManager,
RMDelegationTokenSecretManager rmDTSecretManager) |
ClientRMService(RMContext rmContext,
YarnScheduler scheduler,
RMAppManager rmAppManager,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager applicationACLsManager,
QueueACLsManager queueACLsManager,
RMDelegationTokenSecretManager rmDTSecretManager,
org.apache.hadoop.yarn.util.Clock clock) |
NodesListManager(RMContext rmContext) |
ResourceManager.ApplicationAttemptEventDispatcher(RMContext rmContext) |
ResourceManager.ApplicationEventDispatcher(RMContext rmContext) |
ResourceManager.NodeEventDispatcher(RMContext rmContext) |
ResourceTrackerService(RMContext rmContext,
NodesListManager nodesListManager,
NMLivelinessMonitor nmLivelinessMonitor,
RMContainerTokenSecretManager containerTokenSecretManager,
NMTokenSecretManagerInRM nmTokenSecretManager) |
RMAppManager(RMContext context,
YarnScheduler scheduler,
ApplicationMasterService masterService,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager applicationACLsManager,
org.apache.hadoop.conf.Configuration conf) |
RMNMInfo(RMContext rmc,
ResourceScheduler sched)
Constructor for RMNMInfo registers the bean with JMX.
|
Modifier and Type | Field and Description |
---|---|
protected RMContext |
ApplicationMasterLauncher.context |
Constructor and Description |
---|
AMLauncher(RMContext rmContext,
RMAppAttempt application,
AMLauncherEventType eventType,
org.apache.hadoop.conf.Configuration conf) |
ApplicationMasterLauncher(RMContext context) |
Constructor and Description |
---|
SchedulingMonitor(RMContext rmContext,
SchedulingEditPolicy scheduleEditPolicy) |
Modifier and Type | Method and Description |
---|---|
void |
RMNodeLabelsManager.setRMContext(RMContext rmContext) |
Modifier and Type | Method and Description |
---|---|
void |
CapacityReservationSystem.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
void |
AbstractReservationSystem.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
void |
ReservationSystem.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext)
Re-initialize the
ReservationSystem . |
void |
FairReservationSystem.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
void |
AbstractReservationSystem.setRMContext(RMContext rmContext) |
void |
ReservationSystem.setRMContext(RMContext rmContext)
Set RMContext for
ReservationSystem . |
Constructor and Description |
---|
RMAppImpl(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
RMContext rmContext,
org.apache.hadoop.conf.Configuration config,
String name,
String user,
String queue,
org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
YarnScheduler scheduler,
ApplicationMasterService masterService,
long submitTime,
String applicationType,
Set<String> applicationTags,
org.apache.hadoop.yarn.api.records.ResourceRequest amReq) |
Constructor and Description |
---|
RMAppAttemptImpl(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
RMContext rmContext,
YarnScheduler scheduler,
ApplicationMasterService masterService,
org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext submissionContext,
org.apache.hadoop.conf.Configuration conf,
boolean maybeLastAttempt,
org.apache.hadoop.yarn.api.records.ResourceRequest amReq) |
RMAppAttemptMetrics(org.apache.hadoop.yarn.api.records.ApplicationAttemptId attemptId,
RMContext rmContext) |
Constructor and Description |
---|
RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
String user,
RMContext rmContext) |
RMContainerImpl(org.apache.hadoop.yarn.api.records.Container container,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
String user,
RMContext rmContext,
long creationTime) |
Constructor and Description |
---|
RMNodeImpl(org.apache.hadoop.yarn.api.records.NodeId nodeId,
RMContext context,
String hostName,
int cmPort,
int httpPort,
org.apache.hadoop.net.Node node,
org.apache.hadoop.yarn.api.records.Resource capability,
String nodeManagerVersion) |
Modifier and Type | Field and Description |
---|---|
protected RMContext |
SchedulerApplicationAttempt.rmContext |
protected RMContext |
AbstractYarnScheduler.rmContext |
Modifier and Type | Method and Description |
---|---|
void |
ResourceScheduler.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext)
Re-initialize the
ResourceScheduler . |
void |
ResourceScheduler.setRMContext(RMContext rmContext)
Set RMContext for
ResourceScheduler . |
Constructor and Description |
---|
SchedulerApplicationAttempt(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
Queue queue,
ActiveUsersManager activeUsersManager,
RMContext rmContext) |
Modifier and Type | Method and Description |
---|---|
RMContext |
CapacityScheduler.getRMContext() |
RMContext |
CapacitySchedulerContext.getRMContext() |
Modifier and Type | Method and Description |
---|---|
void |
CapacityScheduler.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
void |
CapacityScheduler.setRMContext(RMContext rmContext) |
Constructor and Description |
---|
FiCaSchedulerApp(org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
Queue queue,
ActiveUsersManager activeUsersManager,
RMContext rmContext) |
Modifier and Type | Method and Description |
---|---|
void |
FairScheduler.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
void |
FairScheduler.setRMContext(RMContext rmContext) |
Constructor and Description |
---|
FSAppAttempt(FairScheduler scheduler,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
FSLeafQueue queue,
ActiveUsersManager activeUsersManager,
RMContext rmContext) |
Modifier and Type | Method and Description |
---|---|
void |
FifoScheduler.reinitialize(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext) |
void |
FifoScheduler.setRMContext(RMContext rmContext) |
Modifier and Type | Field and Description |
---|---|
protected RMContext |
RMDelegationTokenSecretManager.rmContext |
Modifier and Type | Method and Description |
---|---|
void |
DelegationTokenRenewer.setRMContext(RMContext rmContext) |
Constructor and Description |
---|
AMRMTokenSecretManager(org.apache.hadoop.conf.Configuration conf,
RMContext rmContext)
Create an
AMRMTokenSecretManager |
RMDelegationTokenSecretManager(long delegationKeyUpdateInterval,
long delegationTokenMaxLifetime,
long delegationTokenRenewInterval,
long delegationTokenRemoverScanInterval,
RMContext rmContext)
Create a secret manager
|
Copyright © 2019 Apache Software Foundation. All Rights Reserved.