org.apache.hadoop.mapreduce.TaskType#equals ( )源码实例Demo

下面列出了org.apache.hadoop.mapreduce.TaskType#equals ( ) 实例代码,或者点击链接到github查看源代码,也可以在右侧发表评论。

源代码1 项目: RDFS   文件: TestCapacityScheduler.java
/**
 * Verify the number of slots of type 'type' from the queue 'queue'.
 * incrMapIndex and incrReduceIndex are set , when expected output string is
 * changed.these values can be set if the index of
 * "Used capacity: %d (%.1f%% of Capacity)"
 * is changed.
 * 
 * @param queue
 * @param type
 * @param numActiveUsers in the queue at present.
 * @param expectedOccupiedSlots
 * @param expectedOccupiedSlotsPercent
 * @param incrMapIndex
 * @param incrReduceIndex
 */
private void checkOccupiedSlots(
  String queue,
  TaskType type, int numActiveUsers,
  int expectedOccupiedSlots, float expectedOccupiedSlotsPercent,int incrMapIndex
  ,int incrReduceIndex
) {
  scheduler.updateQSIInfoForTests();
  QueueManager queueManager = scheduler.taskTrackerManager.getQueueManager();
  String schedulingInfo =
      queueManager.getJobQueueInfo(queue).getSchedulingInfo();
  String[] infoStrings = schedulingInfo.split("\n");
  int index = -1;
  if (type.equals(TaskType.MAP)) {
    index = 7+ incrMapIndex;
  } else if (type.equals(TaskType.REDUCE)) {
    index = (numActiveUsers == 0 ? 12 : 13 + numActiveUsers)+incrReduceIndex;
  }
  LOG.info(infoStrings[index]);
  assertEquals(String.format("Used capacity: %d (%.1f%% of Capacity)",
      expectedOccupiedSlots, expectedOccupiedSlotsPercent),
      infoStrings[index]);
}
 
源代码2 项目: hadoop   文件: HistoryViewer.java
private void printTasks(TaskType taskType, String status) {
  Map<TaskID, JobHistoryParser.TaskInfo> tasks = job.getAllTasks();
  StringBuffer header = new StringBuffer();
  header.append("\n").append(status).append(" ");
  header.append(taskType).append(" task list for ").append(jobId);
  header.append("\nTaskId\t\tStartTime\tFinishTime\tError");
  if (TaskType.MAP.equals(taskType)) {
    header.append("\tInputSplits");
  }
  header.append("\n====================================================");
  StringBuffer taskList = new StringBuffer();
  for (JobHistoryParser.TaskInfo task : tasks.values()) {
    if (taskType.equals(task.getTaskType()) &&
       (status.equals(task.getTaskStatus())
        || status.equalsIgnoreCase("ALL"))) {
      taskList.setLength(0);
      taskList.append(task.getTaskId());
      taskList.append("\t").append(StringUtils.getFormattedTimeWithDiff(
                 dateFormat, task.getStartTime(), 0));
      taskList.append("\t").append(StringUtils.getFormattedTimeWithDiff(
                 dateFormat, task.getFinishTime(),
                 task.getStartTime())); 
      taskList.append("\t").append(task.getError());
      if (TaskType.MAP.equals(taskType)) {
        taskList.append("\t").append(task.getSplitLocations());
      }
      if (taskList != null) {
        System.out.println(header.toString());
        System.out.println(taskList.toString());
      }
    }
  }
}
 
源代码3 项目: big-c   文件: HistoryViewer.java
private void printTasks(TaskType taskType, String status) {
  Map<TaskID, JobHistoryParser.TaskInfo> tasks = job.getAllTasks();
  StringBuffer header = new StringBuffer();
  header.append("\n").append(status).append(" ");
  header.append(taskType).append(" task list for ").append(jobId);
  header.append("\nTaskId\t\tStartTime\tFinishTime\tError");
  if (TaskType.MAP.equals(taskType)) {
    header.append("\tInputSplits");
  }
  header.append("\n====================================================");
  StringBuffer taskList = new StringBuffer();
  for (JobHistoryParser.TaskInfo task : tasks.values()) {
    if (taskType.equals(task.getTaskType()) &&
       (status.equals(task.getTaskStatus())
        || status.equalsIgnoreCase("ALL"))) {
      taskList.setLength(0);
      taskList.append(task.getTaskId());
      taskList.append("\t").append(StringUtils.getFormattedTimeWithDiff(
                 dateFormat, task.getStartTime(), 0));
      taskList.append("\t").append(StringUtils.getFormattedTimeWithDiff(
                 dateFormat, task.getFinishTime(),
                 task.getStartTime())); 
      taskList.append("\t").append(task.getError());
      if (TaskType.MAP.equals(taskType)) {
        taskList.append("\t").append(task.getSplitLocations());
      }
      if (taskList != null) {
        System.out.println(header.toString());
        System.out.println(taskList.toString());
      }
    }
  }
}
 
源代码4 项目: RDFS   文件: JobTracker.java
void incrementReservations(TaskType type, int reservedSlots) {
  if (type.equals(TaskType.MAP)) {
    reservedMapSlots += reservedSlots;
  } else if (type.equals(TaskType.REDUCE)) {
    reservedReduceSlots += reservedSlots;
  }
}
 
源代码5 项目: RDFS   文件: JobTracker.java
void decrementReservations(TaskType type, int reservedSlots) {
  if (type.equals(TaskType.MAP)) {
    reservedMapSlots -= reservedSlots;
  } else if (type.equals(TaskType.REDUCE)) {
    reservedReduceSlots -= reservedSlots;
  }
}
 
源代码6 项目: hadoop   文件: HistoryViewer.java
private void printAllTaskAttempts(TaskType taskType) {
  Map<TaskID, TaskInfo> tasks = job.getAllTasks();
  StringBuffer taskList = new StringBuffer();
  taskList.append("\n").append(taskType);
  taskList.append(" task list for ").append(job.getJobId());
  taskList.append("\nTaskId\t\tStartTime");
  if (TaskType.REDUCE.equals(taskType)) {
    taskList.append("\tShuffleFinished\tSortFinished");
  }
  taskList.append("\tFinishTime\tHostName\tError\tTaskLogs");
  taskList.append("\n====================================================");
  System.out.println(taskList.toString());
  for (JobHistoryParser.TaskInfo task : tasks.values()) {
    for (JobHistoryParser.TaskAttemptInfo attempt : 
      task.getAllTaskAttempts().values()) {
      if (taskType.equals(task.getTaskType())){
        taskList.setLength(0); 
        taskList.append(attempt.getAttemptId()).append("\t");
        taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat,
                        attempt.getStartTime(), 0)).append("\t");
        if (TaskType.REDUCE.equals(taskType)) {
          taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat,
                          attempt.getShuffleFinishTime(),
                          attempt.getStartTime()));
          taskList.append("\t"); 
          taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat, 
                          attempt.getSortFinishTime(),
                          attempt.getShuffleFinishTime())); 
        } 
        taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat,
                        attempt.getFinishTime(),
                        attempt.getStartTime())); 
        taskList.append("\t"); 
        taskList.append(attempt.getHostname()).append("\t");
        taskList.append(attempt.getError());
        String taskLogsUrl = getTaskLogsUrl(
            WebAppUtils.getHttpSchemePrefix(fs.getConf()), attempt);
        taskList.append(taskLogsUrl != null ? taskLogsUrl : "n/a");
        System.out.println(taskList.toString());
      }
    }
  }
}
 
源代码7 项目: big-c   文件: HistoryViewer.java
private void printAllTaskAttempts(TaskType taskType) {
  Map<TaskID, TaskInfo> tasks = job.getAllTasks();
  StringBuffer taskList = new StringBuffer();
  taskList.append("\n").append(taskType);
  taskList.append(" task list for ").append(job.getJobId());
  taskList.append("\nTaskId\t\tStartTime");
  if (TaskType.REDUCE.equals(taskType)) {
    taskList.append("\tShuffleFinished\tSortFinished");
  }
  taskList.append("\tFinishTime\tHostName\tError\tTaskLogs");
  taskList.append("\n====================================================");
  System.out.println(taskList.toString());
  for (JobHistoryParser.TaskInfo task : tasks.values()) {
    for (JobHistoryParser.TaskAttemptInfo attempt : 
      task.getAllTaskAttempts().values()) {
      if (taskType.equals(task.getTaskType())){
        taskList.setLength(0); 
        taskList.append(attempt.getAttemptId()).append("\t");
        taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat,
                        attempt.getStartTime(), 0)).append("\t");
        if (TaskType.REDUCE.equals(taskType)) {
          taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat,
                          attempt.getShuffleFinishTime(),
                          attempt.getStartTime()));
          taskList.append("\t"); 
          taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat, 
                          attempt.getSortFinishTime(),
                          attempt.getShuffleFinishTime())); 
        } 
        taskList.append(StringUtils.getFormattedTimeWithDiff(dateFormat,
                        attempt.getFinishTime(),
                        attempt.getStartTime())); 
        taskList.append("\t"); 
        taskList.append(attempt.getHostname()).append("\t");
        taskList.append(attempt.getError());
        String taskLogsUrl = getTaskLogsUrl(
            WebAppUtils.getHttpSchemePrefix(fs.getConf()), attempt);
        taskList.append(taskLogsUrl != null ? taskLogsUrl : "n/a");
        System.out.println(taskList.toString());
      }
    }
  }
}