Package org.apache.hadoop.corona

Examples of org.apache.hadoop.corona.SessionHistoryManager


    context.registerUpdater(this);

    expireUnusedFilesInCache = new ExpireUnusedFilesInCache(
      conf, getClock(), new Path(getSystemDir()), fs);

    sessionHistoryManager = new SessionHistoryManager();
    sessionHistoryManager.setConf(conf);

    try {
      String target = conf.getProxyJobTrackerThriftAddress();
      InetSocketAddress addr = NetUtils.createSocketAddr(target);
View Full Code Here


    if (isStandalone) {
      // If this is the remote job tracker, we need to use the session log
      // path of the parent job tracker, since we use the job ID specified
      // by the parent job tracker.
      String parentSessionId = CoronaJobTracker.sessionIdFromJobID(jobId);
      SessionHistoryManager sessionHistoryManager = new SessionHistoryManager();
      sessionHistoryManager.setConf(conf);
      sessionLogPath = sessionHistoryManager.getLogPath(parentSessionId);
      LOG.info("Using session log path " + sessionLogPath + " based on jobId " +
        jobId);
    } else {
      sessionLogPath = sessionDriver.getSessionLog();
    }
View Full Code Here

    if (isStandalone) {
      // If this is the remote job tracker, we need to use the session log
      // path of the parent job tracker, since we use the job ID specified
      // by the parent job tracker.
      String parentSessionId = CoronaJobTracker.sessionIdFromJobID(jobId);
      SessionHistoryManager sessionHistoryManager = new SessionHistoryManager();
      sessionHistoryManager.setConf(conf);
      sessionLogPath = sessionHistoryManager.getLogPath(parentSessionId);
      LOG.info("Using session log path " + sessionLogPath + " based on jobId " +
        jobId);
    } else {
      sessionLogPath = sessionDriver.getSessionLog();
    }
View Full Code Here

      getClock(), conf, new Path(conf.getSessionsLogDir()),
      UNUSED_JOBHISTORY_PATTERN, clearJobHistoryThreshold, clearJobHistoryInterval);

    expireUnusedJobHistory.setName("Job History Cleanup Thread");
    expireUnusedJobHistory.start();
    sessionHistoryManager = new SessionHistoryManager();
    sessionHistoryManager.setConf(conf);

    String target = conf.getProxyJobTrackerThriftAddress();
    InetSocketAddress addr = NetUtils.createSocketAddr(target);
    LOG.info("Trying to start the Thrift Server at: " + target);
View Full Code Here

TOP

Related Classes of org.apache.hadoop.corona.SessionHistoryManager

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.