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.flink.yarn.YarnResourceManagerCallbackHandler.java

/**
 * This class reacts to callbacks from the YARN Resource Manager.
 * In order to preserve actor concurrency safety, this class simply sends
 * corresponding messages to the Yarn resource master actor.
 */
public class YarnResourceManagerCallbackHandler implements AMRMClientAsync.CallbackHandler {

From source file org.apache.helix.provisioning.yarn.RMCallbackHandler.java

class RMCallbackHandler implements AMRMClientAsync.CallbackHandler {
    private static final Log LOG = LogFactory.getLog(RMCallbackHandler.class);
    long startTime;
    /**
     *
     */

From source file org.apache.hoya.yarn.appmaster.HoyaAppMaster.java

/**
 * This is the AM, which directly implements the callbacks from the AM and NM
 */
public class HoyaAppMaster extends CompoundLaunchedService implements AMRMClientAsync.CallbackHandler,
        NMClientAsync.CallbackHandler, RunService, HoyaExitCodes, HoyaKeys, HoyaClusterProtocol,
        ServiceStateChangeListener, RoleKeys, EventCallback, ContainerStartOperation {

From source file org.apache.ignite.yarn.ApplicationMaster.java

/**
 * Application master request containers from Yarn and decides how many resources will be occupied.
 */
public class ApplicationMaster implements AMRMClientAsync.CallbackHandler {
    /** */
    public static final Logger log = Logger.getLogger(ApplicationMaster.class.getSimpleName());

From source file org.apache.metron.maas.service.callback.ContainerRequestListener.java

public class ContainerRequestListener implements AMRMClientAsync.CallbackHandler, NMClientAsync.CallbackHandler {

    private static final Log LOG = LogFactory.getLog(ContainerRequestListener.class);
    private ContainerTracker state;
    private AMRMClientAsync<AMRMClient.ContainerRequest> amRMClient;
    @VisibleForTesting

From source file org.apache.oozie.action.hadoop.AMRMCallBackHandler.java

public class AMRMCallBackHandler implements AMRMClientAsync.CallbackHandler {
    private ErrorHolder errorHolder;

    @Override
    public void onContainersCompleted(List<ContainerStatus> containerStatuses) {
        //noop

From source file org.apache.reef.runtime.yarn.driver.unmanaged.UnmanagedAmTest.java

/**
 * Test REEF Driver in Unmanaged AM mode on YARN.
 */
public final class UnmanagedAmTest implements AMRMClientAsync.CallbackHandler, NMClientAsync.CallbackHandler {

    private static final Logger LOG = Logger.getLogger(UnmanagedAmTest.class.getName());

From source file org.apache.reef.runtime.yarn.driver.YarnContainerManager.java

final class YarnContainerManager implements AMRMClientAsync.CallbackHandler, NMClientAsync.CallbackHandler {

    private static final Logger LOG = Logger.getLogger(YarnContainerManager.class.getName());

    private static final String RUNTIME_NAME = "YARN";

From source file org.apache.samza.job.yarn.refactor.YarnClusterResourceManager.java

/**
 *
 * An {@link YarnClusterResourceManager} implements a ClusterResourceManager using Yarn as the underlying
 * resource manager. This class is as an adaptor between Yarn and translates Yarn callbacks into
 * Samza specific callback methods as specified in Callback.
 *

From source file org.apache.samza.job.yarn.YarnClusterResourceManager.java

/**
 *
 * An {@link YarnClusterResourceManager} implements a ClusterResourceManager using Yarn as the underlying
 * resource manager. This class is as an adaptor between Yarn and translates Yarn callbacks into
 * Samza specific callback methods as specified in Callback.
 *