public abstract class RMContainerRequestor extends RMCommunicator
RMCommunicator.AllocatorRunnable| Modifier and Type | Field and Description | 
|---|---|
| protected int | lastResponseID | 
| protected Set<org.apache.hadoop.yarn.api.records.ContainerId> | pendingRelease | 
allocatorThread, applicationACLs, applicationId, eventHandler, isSignalled, scheduler| Constructor and Description | 
|---|
| RMContainerRequestor(ClientService clientService,
                    AppContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | addContainerReq(org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest req) | 
| protected void | addOpportunisticResourceRequest(org.apache.hadoop.yarn.api.records.Priority priority,
                               org.apache.hadoop.yarn.api.records.Resource capability) | 
| protected void | addOutstandingRequestOnResync() | 
| protected void | computeIgnoreBlacklisting() | 
| protected void | containerFailedOnHost(String hostName) | 
| protected void | decContainerReq(org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest req) | 
| protected org.apache.hadoop.yarn.api.records.Resource | getAvailableResources() | 
| Set<String> | getBlacklistedNodes() | 
| protected org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest | getFilteredContainerRequest(org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest orig) | 
| protected boolean | isNodeBlacklisted(String hostname) | 
| protected org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse | makeRemoteRequest() | 
| protected void | release(org.apache.hadoop.yarn.api.records.ContainerId containerId) | 
| protected void | serviceInit(org.apache.hadoop.conf.Configuration conf) | 
| protected void | setRequestLimit(org.apache.hadoop.yarn.api.records.Priority priority,
               org.apache.hadoop.yarn.api.records.Resource capability,
               int limit) | 
createSchedulerProxy, doUnregistration, getApplicationProgress, getContext, getJob, getLastHeartbeatTime, getMaxContainerCapability, getSchedulerResourceTypes, heartbeat, isApplicationMasterRegistered, register, runOnNextHeartbeat, serviceStart, serviceStop, setShouldUnregister, setSignalled, startAllocatorThread, unregisterclose, getBlockers, getConfig, getFailureCause, getFailureState, getLifecycleHistory, getName, getServiceState, getStartTime, init, isInState, noteFailure, putBlocker, registerGlobalListener, registerServiceListener, removeBlocker, setConfig, start, stop, toString, unregisterGlobalListener, unregisterServiceListener, waitForServiceToStopprotected int lastResponseID
protected Set<org.apache.hadoop.yarn.api.records.ContainerId> pendingRelease
public RMContainerRequestor(ClientService clientService, AppContext context)
protected void serviceInit(org.apache.hadoop.conf.Configuration conf)
                    throws Exception
serviceInit in class RMCommunicatorExceptionprotected org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse makeRemoteRequest()
                                                                                 throws org.apache.hadoop.yarn.exceptions.YarnException,
                                                                                        IOException
org.apache.hadoop.yarn.exceptions.YarnExceptionIOExceptionprotected void addOutstandingRequestOnResync()
protected void computeIgnoreBlacklisting()
protected void containerFailedOnHost(String hostName)
protected org.apache.hadoop.yarn.api.records.Resource getAvailableResources()
protected void addContainerReq(org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest req)
protected void decContainerReq(org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest req)
protected void addOpportunisticResourceRequest(org.apache.hadoop.yarn.api.records.Priority priority,
                                               org.apache.hadoop.yarn.api.records.Resource capability)
protected void release(org.apache.hadoop.yarn.api.records.ContainerId containerId)
protected boolean isNodeBlacklisted(String hostname)
protected org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest getFilteredContainerRequest(org.apache.hadoop.mapreduce.v2.app.rm.RMContainerRequestor.ContainerRequest orig)
protected void setRequestLimit(org.apache.hadoop.yarn.api.records.Priority priority,
                               org.apache.hadoop.yarn.api.records.Resource capability,
                               int limit)
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.