Package org.apache.hadoop.mapred.CoronaStateUpdate

Examples of org.apache.hadoop.mapred.CoronaStateUpdate.TaskTimeout


   */
  public void expiredLaunchingTask(TaskAttemptID taskId) {
    synchronized (lockObject) {
      String trackerName = taskLookupTable.getAssignedTracker(taskId);
      trackerStats.recordTimeout(trackerName);
      localJTSubmitter.submit(new TaskTimeout(trackerName));
      failTask(taskId, "Error launching task", false);
    }
  }
View Full Code Here


   */
  public void expiredRunningTask(TaskAttemptID taskId) {
    synchronized (lockObject) {
      String trackerName = taskLookupTable.getAssignedTracker(taskId);
      trackerStats.recordTimeout(trackerName);
      localJTSubmitter.submit(new TaskTimeout(trackerName));
      failTask(taskId, "Timeout running task", false);
    }
  }
View Full Code Here

        if (launch != null) {
          LOG.info("Restoring launch " + launch);
          remoteJT.restoreTaskLaunch(launch);
          continue;
        }
        TaskTimeout timeout = update.getTaskTimeout();
        if (timeout != null) {
          String trackerName = timeout.getTrackerName();
          LOG.info("Restoring timeout on " + trackerName);
          remoteJT.restoreTaskTimeout(trackerName);
          continue;
        }
      }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.mapred.CoronaStateUpdate.TaskTimeout

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.