public class NodeStatusUpdaterImpl extends org.apache.hadoop.service.AbstractService implements NodeStatusUpdater
Modifier and Type | Field and Description |
---|---|
static int |
DEFAULT_MR_AM_CPU_VCORES
The default for number of virtual cores a MR app master needs.
|
static int |
DEFAULT_MR_AM_VMEM_MB
The default for amount of memory a MR app master needs.
|
static int |
DEFAULT_REDUCE_CPU_VCORES
The default for number of virtual cores a reducer needs.
|
static double |
DEFAULT_REDUCE_DISK
The default for number of disk a reducer needs.
|
static int |
DEFAULT_REDUCE_MEMORY_MB
The default for amount of memory a reducer needs.
|
static int |
DEFAULT_SCHEDULER_MINIMUM_ALLOCATION_MB
The default for minimum memory allocated by the scheduler.
|
static String |
YARN_NODEMANAGER_DURATION_TO_TRACK_STOPPED_CONTAINERS |
Constructor and Description |
---|
NodeStatusUpdaterImpl(Context context,
org.apache.hadoop.yarn.event.Dispatcher dispatcher,
NodeHealthCheckerService healthChecker,
NodeManagerMetrics metrics) |
Modifier and Type | Method and Description |
---|---|
void |
clearFinishedContainersFromCache() |
protected List<org.apache.hadoop.yarn.api.records.ContainerStatus> |
getContainerStatuses() |
protected org.apache.hadoop.yarn.server.api.ResourceTracker |
getRMClient() |
long |
getRMIdentifier() |
boolean |
isContainerRecentlyStopped(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
protected boolean |
isTokenKeepAliveEnabled(org.apache.hadoop.conf.Configuration conf) |
protected void |
rebootNodeStatusUpdaterAndRegisterWithRM() |
protected void |
registerWithRM() |
void |
removeVeryOldStoppedContainersFromCache() |
void |
sendOutofBandHeartBeat() |
protected void |
serviceInit(org.apache.hadoop.conf.Configuration conf) |
protected void |
serviceStart() |
protected void |
serviceStop() |
protected void |
startStatusUpdater() |
protected void |
stopRMProxy() |
void |
updateStoppedContainersInCache(org.apache.hadoop.yarn.api.records.ContainerId containerId) |
close, getBlockers, getConfig, getFailureCause, getFailureState, getLifecycleHistory, getName, getServiceState, getStartTime, init, isInState, noteFailure, putBlocker, registerGlobalListener, registerServiceListener, removeBlocker, setConfig, start, stop, toString, unregisterGlobalListener, unregisterServiceListener, waitForServiceToStop
public static final String YARN_NODEMANAGER_DURATION_TO_TRACK_STOPPED_CONTAINERS
public static final int DEFAULT_MR_AM_VMEM_MB
public static final int DEFAULT_MR_AM_CPU_VCORES
public static final int DEFAULT_REDUCE_MEMORY_MB
public static final int DEFAULT_REDUCE_CPU_VCORES
public static final double DEFAULT_REDUCE_DISK
public static final int DEFAULT_SCHEDULER_MINIMUM_ALLOCATION_MB
public NodeStatusUpdaterImpl(Context context, org.apache.hadoop.yarn.event.Dispatcher dispatcher, NodeHealthCheckerService healthChecker, NodeManagerMetrics metrics)
protected void serviceInit(org.apache.hadoop.conf.Configuration conf) throws Exception
serviceInit
in class org.apache.hadoop.service.AbstractService
Exception
protected void serviceStart() throws Exception
serviceStart
in class org.apache.hadoop.service.AbstractService
Exception
protected void serviceStop() throws Exception
serviceStop
in class org.apache.hadoop.service.AbstractService
Exception
protected void rebootNodeStatusUpdaterAndRegisterWithRM()
protected void stopRMProxy()
@InterfaceAudience.Private protected boolean isTokenKeepAliveEnabled(org.apache.hadoop.conf.Configuration conf)
protected org.apache.hadoop.yarn.server.api.ResourceTracker getRMClient() throws IOException
IOException
protected void registerWithRM() throws org.apache.hadoop.yarn.exceptions.YarnException, IOException
org.apache.hadoop.yarn.exceptions.YarnException
IOException
protected List<org.apache.hadoop.yarn.api.records.ContainerStatus> getContainerStatuses()
public void sendOutofBandHeartBeat()
sendOutofBandHeartBeat
in interface NodeStatusUpdater
public boolean isContainerRecentlyStopped(org.apache.hadoop.yarn.api.records.ContainerId containerId)
isContainerRecentlyStopped
in interface NodeStatusUpdater
@InterfaceAudience.Private public void updateStoppedContainersInCache(org.apache.hadoop.yarn.api.records.ContainerId containerId)
public void clearFinishedContainersFromCache()
clearFinishedContainersFromCache
in interface NodeStatusUpdater
@InterfaceAudience.Private public void removeVeryOldStoppedContainersFromCache()
public long getRMIdentifier()
getRMIdentifier
in interface NodeStatusUpdater
protected void startStatusUpdater()
Copyright © 2014 Apache Software Foundation. All Rights Reserved.