Modifier and Type | Class and Description |
---|---|
static class |
AMHeartbeatRequestHandler.AsyncAllocateRequestInfo
Data structure that encapsulates AllocateRequest and AsyncCallback
instance.
|
class |
AMHeartbeatRequestHandler.HeartBeatThreadUncaughtExceptionHandler
Uncaught exception handler for the background heartbeat thread.
|
Thread.State, Thread.UncaughtExceptionHandler
Modifier and Type | Field and Description |
---|---|
static org.slf4j.Logger |
LOG |
MAX_PRIORITY, MIN_PRIORITY, NORM_PRIORITY
Constructor and Description |
---|
AMHeartbeatRequestHandler(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
AMRMClientRelayer rmProxyRelayer) |
Modifier and Type | Method and Description |
---|---|
void |
allocateAsync(org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest request,
org.apache.hadoop.yarn.util.AsyncCallback<org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse> callback)
Sends the specified heart beat request to the resource manager and invokes
the callback asynchronously with the response.
|
void |
drainHeartbeatThread() |
int |
getRequestQueueSize() |
void |
resetLastResponseId()
Reset the lastResponseId to zero.
|
void |
run() |
void |
setUGI(org.apache.hadoop.security.UserGroupInformation ugi)
Set the UGI for RM connection.
|
void |
shutdown()
Shutdown the thread.
|
activeCount, checkAccess, clone, countStackFrames, currentThread, destroy, dumpStack, enumerate, getAllStackTraces, getContextClassLoader, getDefaultUncaughtExceptionHandler, getId, getName, getPriority, getStackTrace, getState, getThreadGroup, getUncaughtExceptionHandler, holdsLock, interrupt, interrupted, isAlive, isDaemon, isInterrupted, join, join, join, resume, setContextClassLoader, setDaemon, setDefaultUncaughtExceptionHandler, setName, setPriority, setUncaughtExceptionHandler, sleep, sleep, start, stop, stop, suspend, toString, yield
public AMHeartbeatRequestHandler(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.yarn.api.records.ApplicationId applicationId, AMRMClientRelayer rmProxyRelayer)
public void shutdown()
public void resetLastResponseId()
public void setUGI(org.apache.hadoop.security.UserGroupInformation ugi)
public void allocateAsync(org.apache.hadoop.yarn.api.protocolrecords.AllocateRequest request, org.apache.hadoop.yarn.util.AsyncCallback<org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse> callback) throws org.apache.hadoop.yarn.exceptions.YarnException
request
- the allocate requestcallback
- the callback method for the requestorg.apache.hadoop.yarn.exceptions.YarnException
- if registerAM is not called yetpublic void drainHeartbeatThread()
public int getRequestQueueSize()
Copyright © 2020 Apache Software Foundation. All rights reserved.