Example usage for org.apache.hadoop.yarn.client.api.async AMRMClientAsync.CallbackHandler interface-usage

List of usage examples for org.apache.hadoop.yarn.client.api.async AMRMClientAsync.CallbackHandler interface-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.yarn.client.api.async AMRMClientAsync.CallbackHandler interface-usage.

Usage

From source file org.apache.slider.server.appmaster.SliderAppMaster.java

/**
 * This is the AM, which directly implements the callbacks from the AM and NM
 */
public class SliderAppMaster extends AbstractSliderLaunchedService
        implements AMRMClientAsync.CallbackHandler, NMClientAsync.CallbackHandler, RunService, SliderExitCodes,
        SliderKeys, SliderClusterProtocol, ServiceStateChangeListener, RoleKeys, ProviderCompleted {

From source file org.apache.tez.dag.app.rm.DagAwareYarnTaskScheduler.java

/**
 * A YARN task scheduler that is aware of the dependencies between vertices
 * in the DAG and takes them into account when deciding how to schedule
 * and preempt tasks.
 *
 * This scheduler makes the assumption that vertex IDs start at 0 and are

From source file org.apache.tez.dag.app.rm.TaskScheduler.java

public class TaskScheduler extends AbstractService implements AMRMClientAsync.CallbackHandler {
    private static final Log LOG = LogFactory.getLog(TaskScheduler.class);

    public interface TaskSchedulerAppCallback {
        public class AppFinalStatus {
            public final FinalApplicationStatus exitStatus;

From source file org.apache.tez.dag.app.rm.YarnTaskSchedulerService.java

public class YarnTaskSchedulerService extends TaskSchedulerService implements AMRMClientAsync.CallbackHandler {
    private static final Log LOG = LogFactory.getLog(YarnTaskSchedulerService.class);

    final TezAMRMClientAsync<CookieContainerRequest> amRmClient;
    final TaskSchedulerAppCallback realAppClient;
    final TaskSchedulerAppCallback appClientDelegate;

From source file tachyon.yarn.ApplicationMaster.java

/**
 * Actual owner of Tachyon running on Yarn. The YARN ResourceManager will launch this
 * ApplicationMaster on an allocated container. The ApplicationMaster communicates with YARN
 * cluster, and handles application execution. It performs operations in an asynchronous fashion.
 */
public final class ApplicationMaster implements AMRMClientAsync.CallbackHandler {

From source file yarnkit.appmaster.ApplicationMasterService.java

/**
 * A service that handles the server-side invocation of {@code ApplicationMaster}.
 */
public final class ApplicationMasterService extends AbstractScheduledService
        implements AMRMClientAsync.CallbackHandler {
    private static final Log LOG = LogFactory.getLog(ApplicationMasterService.class);