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 alluxio.yarn.ApplicationMaster.java

/**
 * Actual owner of Alluxio running on Yarn. The YARN ResourceManager will launch this
 * ApplicationMaster on an allocated container. The ApplicationMaster communicates with the YARN
 * cluster, and handles application execution. It performs operations asynchronously.
 */
@NotThreadSafe

From source file com.cloudera.kitten.appmaster.service.ApplicationMasterServiceImpl1.java

public class ApplicationMasterServiceImpl1 extends AbstractScheduledService
        implements ApplicationMasterService, AMRMClientAsync.CallbackHandler {

    private static final Log LOG = LogFactory.getLog(ApplicationMasterServiceImpl1.class);

    private final ApplicationMasterParameters parameters;

From source file com.cloudera.kitten.appmaster.service.WorkflowService.java

public class WorkflowService extends AbstractScheduledService
        implements ApplicationMasterService, AMRMClientAsync.CallbackHandler {

    private static final Log LOG = LogFactory.getLog(WorkflowService.class);

    public final WorkflowParameters parameters;

From source file com.cloudera.llama.am.yarn.YarnRMConnector.java

public class YarnRMConnector implements RMConnector, Configurable, AMRMClientAsync.CallbackHandler {
    private static final Logger LOG = LoggerFactory.getLogger(YarnRMConnector.class);

    public static final String PREFIX_KEY = LlamaAM.PREFIX_KEY + "yarn.";

    public static final String AM_PRIORITY_KEY = PREFIX_KEY + "priority";

From source file com.gpiskas.yarn.AppMaster.java

public class AppMaster implements AMRMClientAsync.CallbackHandler {

    private YarnConfiguration conf = new YarnConfiguration();
    private NMClient nmClient;
    private int containerCount = 3;

From source file com.hazelcast.yarn.ApplicationMaster.java

public class ApplicationMaster implements AMRMClientAsync.CallbackHandler {
    public static final Logger LOG = Logger.getLogger(ApplicationMaster.class.getSimpleName());

    public static final int TIMEOUT = 2000;

    private FileSystem hdfs;

From source file com.resa.yarn.AppMaster.java

public class AppMaster implements AMRMClientAsync.CallbackHandler {

    private YarnConfiguration conf = new YarnConfiguration();
    private NMClient nmClient;
    private int containerCount = 4;

From source file husky.server.HuskyRMCallbackHandler.java

public class HuskyRMCallbackHandler implements AMRMClientAsync.CallbackHandler {
    private static final Logger LOG = Logger.getLogger(HuskyRMCallbackHandler.class.getName());

    private Thread masterThread = null;
    private ArrayList<Thread> mContainerThreads = new ArrayList<Thread>();
    private int mNumCompletedContainers = 0;

From source file hws.core.JobMaster.java

/**
 * This class implements a simple async app master.
 * In real usages, the callbacks should execute in a separate thread or thread pool
 */
public class JobMaster implements AMRMClientAsync.CallbackHandler {
    private Configuration configuration;

From source file org.apache.flink.yarn.YarnResourceManager.java

/**
 * The yarn implementation of the resource manager. Used when the system is started
 * via the resource framework YARN.
 */
public class YarnResourceManager extends ResourceManager<ResourceID> implements AMRMClientAsync.CallbackHandler {
    protected final Logger LOG = LoggerFactory.getLogger(getClass());