@InterfaceAudience.Public @InterfaceStability.Stable public abstract class NMClientAsync extends AbstractService
NMClientAsync
handles communication with all the NodeManagers
and provides asynchronous updates on getting responses from them. It
maintains a thread pool to communicate with individual NMs where a number of
worker threads process requests to NMs by using NMClientImpl
. The max
size of the thread pool is configurable through
YarnConfiguration.NM_CLIENT_ASYNC_THREAD_POOL_MAX_SIZE
.
It should be used in conjunction with a CallbackHandler. For example
class MyCallbackHandler extends NMClientAsync.AbstractCallbackHandler {
public void onContainerStarted(ContainerId containerId,
Map<String, ByteBuffer> allServiceResponse) {
[post process after the container is started, process the response]
}
public void onContainerResourceIncreased(ContainerId containerId,
Resource resource) {
[post process after the container resource is increased]
}
public void onContainerStatusReceived(ContainerId containerId,
ContainerStatus containerStatus) {
[make use of the status of the container]
}
public void onContainerStopped(ContainerId containerId) {
[post process after the container is stopped]
}
public void onStartContainerError(
ContainerId containerId, Throwable t) {
[handle the raised exception]
}
public void onGetContainerStatusError(
ContainerId containerId, Throwable t) {
[handle the raised exception]
}
public void onStopContainerError(
ContainerId containerId, Throwable t) {
[handle the raised exception]
}
}
The client's life-cycle should be managed like the following:
NMClientAsync asyncClient =
NMClientAsync.createNMClientAsync(new MyCallbackhandler());
asyncClient.init(conf);
asyncClient.start();
asyncClient.startContainer(container, containerLaunchContext);
[... wait for container being started]
asyncClient.getContainerStatus(container.getId(), container.getNodeId(),
container.getContainerToken());
[... handle the status in the callback instance]
asyncClient.stopContainer(container.getId(), container.getNodeId(),
container.getContainerToken());
[... wait for container being stopped]
asyncClient.stop();
Modifier and Type | Field and Description |
---|---|
protected org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler |
callbackHandler |
protected NMClient |
client |
Modifier | Constructor and Description |
---|---|
protected |
NMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler) |
protected |
NMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
Deprecated.
Use
NMClientAsync(AbstractCallbackHandler)
instead. |
protected |
NMClientAsync(String name,
org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler) |
protected |
NMClientAsync(String name,
org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
Deprecated.
Use
NMClientAsync(String, AbstractCallbackHandler)
instead. |
protected |
NMClientAsync(String name,
NMClient client,
org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler) |
protected |
NMClientAsync(String name,
NMClient client,
org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
commitLastReInitializationAsync(ContainerId containerId)
Commit last reInitialization of the specified container.
|
static NMClientAsync |
createNMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler) |
static NMClientAsync |
createNMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
Deprecated.
Use
createNMClientAsync(AbstractCallbackHandler)
instead. |
org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler |
getCallbackHandler() |
NMClient |
getClient() |
abstract void |
getContainerStatusAsync(ContainerId containerId,
NodeId nodeId) |
abstract void |
increaseContainerResourceAsync(Container container)
Deprecated.
|
abstract void |
reInitializeContainerAsync(ContainerId containerId,
ContainerLaunchContext containerLaunchContex,
boolean autoCommit)
Re-Initialize the Container.
|
abstract void |
restartContainerAsync(ContainerId containerId)
Restart the specified container.
|
abstract void |
rollbackLastReInitializationAsync(ContainerId containerId)
Rollback last reInitialization of the specified container.
|
void |
setCallbackHandler(org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler) |
void |
setClient(NMClient client) |
abstract void |
startContainerAsync(Container container,
ContainerLaunchContext containerLaunchContext) |
abstract void |
stopContainerAsync(ContainerId containerId,
NodeId nodeId) |
abstract void |
updateContainerResourceAsync(Container container)
Update the resources of a container.
|
close, getBlockers, getConfig, getFailureCause, getFailureState, getLifecycleHistory, getName, getServiceState, getStartTime, init, isInState, noteFailure, putBlocker, registerGlobalListener, registerServiceListener, removeBlocker, serviceInit, serviceStart, serviceStop, setConfig, start, stop, toString, unregisterGlobalListener, unregisterServiceListener, waitForServiceToStop
protected NMClient client
protected org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler
protected NMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler)
protected NMClientAsync(String name, org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler)
protected NMClientAsync(String name, NMClient client, org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler)
@Deprecated protected NMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
NMClientAsync(AbstractCallbackHandler)
instead.@Deprecated protected NMClientAsync(String name, org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
NMClientAsync(String, AbstractCallbackHandler)
instead.@InterfaceAudience.Private @Deprecated protected NMClientAsync(String name, NMClient client, org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
public static NMClientAsync createNMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler callbackHandler)
@Deprecated public static NMClientAsync createNMClientAsync(org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
createNMClientAsync(AbstractCallbackHandler)
instead.public abstract void startContainerAsync(Container container, ContainerLaunchContext containerLaunchContext)
@Deprecated public abstract void increaseContainerResourceAsync(Container container)
public abstract void updateContainerResourceAsync(Container container)
Update the resources of a container.
The ApplicationMaster
or other applications that use the
client must provide the details of the container, including the Id and
the target resource encapsulated in the updated container token via
Container
.
container
- the container with updated token.public abstract void reInitializeContainerAsync(ContainerId containerId, ContainerLaunchContext containerLaunchContex, boolean autoCommit)
Re-Initialize the Container.
containerId
- the Id of the container to Re-Initialize.containerLaunchContex
- the updated ContainerLaunchContext.autoCommit
- commit re-initialization automatically ?public abstract void restartContainerAsync(ContainerId containerId)
Restart the specified container.
containerId
- the Id of the container to restart.public abstract void rollbackLastReInitializationAsync(ContainerId containerId)
Rollback last reInitialization of the specified container.
containerId
- the Id of the container to restart.public abstract void commitLastReInitializationAsync(ContainerId containerId)
Commit last reInitialization of the specified container.
containerId
- the Id of the container to commit reInitialize.public abstract void stopContainerAsync(ContainerId containerId, NodeId nodeId)
public abstract void getContainerStatusAsync(ContainerId containerId, NodeId nodeId)
public NMClient getClient()
public void setClient(NMClient client)
public org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler getCallbackHandler()
public void setCallbackHandler(org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler callbackHandler)
Copyright © 2019 Apache Software Foundation. All rights reserved.