public class OpportunisticContainerAllocatorAMService extends ApplicationMasterService implements org.apache.hadoop.yarn.server.api.DistributedSchedulingAMProtocol, org.apache.hadoop.yarn.event.EventHandler<SchedulerEvent>
ApplicationMasterService.AllocateResponseLockEMPTY_ALLOCATION, masterServiceAddress, recordFactory, rmContext, server| Constructor and Description | 
|---|
| OpportunisticContainerAllocatorAMService(RMContext rmContext,
                                        YarnScheduler scheduler) | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.yarn.server.api.protocolrecords.DistributedSchedulingAllocateResponse | allocateForDistributedScheduling(org.apache.hadoop.yarn.server.api.protocolrecords.DistributedSchedulingAllocateRequest request) | 
| protected List<org.apache.hadoop.yarn.ams.ApplicationMasterServiceProcessor> | getProcessorList(org.apache.hadoop.conf.Configuration conf) | 
| org.apache.hadoop.ipc.Server | getServer(org.apache.hadoop.yarn.ipc.YarnRPC rpc,
         org.apache.hadoop.conf.Configuration serverConf,
         InetSocketAddress addr,
         AMRMTokenSecretManager secretManager) | 
| void | handle(SchedulerEvent event) | 
| org.apache.hadoop.yarn.server.api.protocolrecords.RegisterDistributedSchedulingAMResponse | registerApplicationMasterForDistributedScheduling(org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest request) | 
| protected void | serviceStop() | 
allocate, finishApplicationMaster, getBindAddress, getProcessingChain, getServer, hasApplicationMasterRegistered, refreshServiceAcls, registerAppAttempt, registerApplicationMaster, serviceInit, serviceStart, setAttemptLastResponseId, unregisterAttemptclose, getBlockers, getConfig, getFailureCause, getFailureState, getLifecycleHistory, getName, getServiceState, getStartTime, init, isInState, noteFailure, putBlocker, registerGlobalListener, registerServiceListener, removeBlocker, setConfig, start, stop, toString, unregisterGlobalListener, unregisterServiceListener, waitForServiceToStoppublic OpportunisticContainerAllocatorAMService(RMContext rmContext, YarnScheduler scheduler)
public org.apache.hadoop.ipc.Server getServer(org.apache.hadoop.yarn.ipc.YarnRPC rpc,
                                              org.apache.hadoop.conf.Configuration serverConf,
                                              InetSocketAddress addr,
                                              AMRMTokenSecretManager secretManager)
getServer in class ApplicationMasterServiceprotected List<org.apache.hadoop.yarn.ams.ApplicationMasterServiceProcessor> getProcessorList(org.apache.hadoop.conf.Configuration conf)
getProcessorList in class ApplicationMasterServicepublic org.apache.hadoop.yarn.server.api.protocolrecords.RegisterDistributedSchedulingAMResponse registerApplicationMasterForDistributedScheduling(org.apache.hadoop.yarn.api.protocolrecords.RegisterApplicationMasterRequest request)
                                                                                                                                            throws org.apache.hadoop.yarn.exceptions.YarnException,
                                                                                                                                                   IOException
registerApplicationMasterForDistributedScheduling in interface org.apache.hadoop.yarn.server.api.DistributedSchedulingAMProtocolorg.apache.hadoop.yarn.exceptions.YarnExceptionIOExceptionpublic org.apache.hadoop.yarn.server.api.protocolrecords.DistributedSchedulingAllocateResponse allocateForDistributedScheduling(org.apache.hadoop.yarn.server.api.protocolrecords.DistributedSchedulingAllocateRequest request)
                                                                                                                         throws org.apache.hadoop.yarn.exceptions.YarnException,
                                                                                                                                IOException
allocateForDistributedScheduling in interface org.apache.hadoop.yarn.server.api.DistributedSchedulingAMProtocolorg.apache.hadoop.yarn.exceptions.YarnExceptionIOExceptionprotected void serviceStop()
                    throws Exception
serviceStop in class ApplicationMasterServiceExceptionpublic void handle(SchedulerEvent event)
handle in interface org.apache.hadoop.yarn.event.EventHandler<SchedulerEvent>Copyright © 2008–2023 Apache Software Foundation. All rights reserved.