Example usage for org.apache.hadoop.yarn.server.api ApplicationTerminationContext getApplicationId

List of usage examples for org.apache.hadoop.yarn.server.api ApplicationTerminationContext getApplicationId

Introduction

In this page you can find the example usage for org.apache.hadoop.yarn.server.api ApplicationTerminationContext getApplicationId.

Prototype

public ApplicationId getApplicationId() 

Source Link

Document

Get ApplicationId of the application being stopped.

Usage

From source file:com.mellanox.hadoop.mapred.UdaShuffleHandler.java

License:Apache License

@Override
public void stopApplication(ApplicationTerminationContext context) {
    ApplicationId appId = context.getApplicationId();
    LOG.info("stopApplication of UdaShuffleHandler");
    JobID jobId = new JobID(Long.toString(appId.getClusterTimestamp()), appId.getId());
    rdmaChannel.removeJob(jobId);//from   w  ww . j  a  v  a2 s .c  om
    LOG.info("stopApplication of UdaShuffleHandler is done");

}

From source file:org.apache.spark.network.yarn.YarnShuffleService.java

License:Apache License

@Override
public void stopApplication(ApplicationTerminationContext context) {
    String appId = context.getApplicationId().toString();
    try {//from   w w  w  .  ja v  a2  s.  c  o m
        if (isAuthenticationEnabled()) {
            AppId fullId = new AppId(appId);
            if (db != null) {
                try {
                    db.delete(dbAppKey(fullId));
                } catch (IOException e) {
                    logger.error("Error deleting {} from executor state db", appId, e);
                }
            }
            secretManager.unregisterApp(appId);
        }
        blockHandler.applicationRemoved(appId, false /* clean up local dirs */);
    } catch (Exception e) {
        logger.error("Exception when stopping application {}", appId, e);
    }
}

From source file:org.apache.tajo.pullserver.PullServerAuxService.java

License:Apache License

@Override
public void stopApplication(ApplicationTerminationContext appStopContext) {
    userRsrc.remove(appStopContext.getApplicationId().toString());
}

From source file:org.apache.tajo.yarn.TajoPullServerService.java

License:Apache License

@Override
public void stopApplication(ApplicationTerminationContext context) {
    userRsrc.remove(context.getApplicationId().toString());
}

From source file:org.apache.tez.auxservices.ShuffleHandler.java

License:Apache License

@Override
public void stopApplication(ApplicationTerminationContext context) {
    ApplicationId appId = context.getApplicationId();
    JobID jobId = new JobID(Long.toString(appId.getClusterTimestamp()), appId.getId());
    try {/*  ww  w. j  av  a 2s. c  om*/
        removeJobShuffleInfo(jobId);
    } catch (IOException e) {
        LOG.error("Error during stopApp", e);
        // TODO add API to AuxiliaryServices to report failures
    }
}

From source file:org.apache.tez.engine.common.shuffle.server.ShuffleHandler.java

License:Apache License

@Override
public void stopApplication(ApplicationTerminationContext context) {
    ApplicationId appId = context.getApplicationId();
    secretManager.removeTokenForJob(appId.toString());
    userRsrc.remove(appId.toString());/*  w  ww  .  ja v  a 2s  . co  m*/
}