Examples of TaskFinishedEvent


Examples of com.vmware.aurora.vc.vcevent.VcEventHandlers.TaskFinishedEvent

   private void fireTaskFinishedEventHandlers(ManagedObjectReference taskMoRef,
                                              TaskInfo.State state)
   throws Exception {
      VcEventHandlers handlers = VcEventHandlers.getInstance();
      /* Create and fire TaskFinished pseudo-event. */
      TaskFinishedEvent taskEvent = handlers.new TaskFinishedEvent(taskMoRef, state);
      handlers.fire(taskEvent);
      dispatchedTaskCount++;    // stats only, unlocked ok.
   }
View Full Code Here

Examples of net.sourceforge.fullsync.TaskFinishedEvent

      stats.bytesTransferred += source.getSize();
    }
    catch (IOException ioe) {
      // FIXME that's not right, the task does not neccessarily be the one
      // that throws this exception as there are flushs involved
      fireTaskFinished(new TaskFinishedEvent(task, ioe.getMessage()));
    }
  }
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      task.eventHandler.handle(new JobTaskEvent(
          task.taskId, TaskState.SUCCEEDED));
      LOG.info("Task succeeded with attempt " + task.successfulAttempt);
      // issue kill to all other attempts
      if (task.historyTaskStartGenerated) {
        TaskFinishedEvent tfe = createTaskFinishedEvent(task,
            TaskState.SUCCEEDED);
        task.eventHandler.handle(new JobHistoryEvent(task.taskId.getJobId(),
            tfe));
      }
      for (TaskAttempt attempt : task.attempts.values()) {
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      eventHandler.handle(new JobTaskAttemptCompletedEvent(tce));
    }
  }

  private static TaskFinishedEvent createTaskFinishedEvent(TaskImpl task, TaskState taskState) {
    TaskFinishedEvent tfe =
      new TaskFinishedEvent(TypeConverter.fromYarn(task.taskId),
        task.getFinishTime(task.successfulAttempt),
        TypeConverter.fromYarn(task.taskId.getTaskType()),
        taskState.toString(),
        task.getCounters());
    return tfe;
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      task.eventHandler.handle(new JobTaskEvent(
          task.taskId, TaskState.SUCCEEDED));
      LOG.info("Task succeeded with attempt " + task.successfulAttempt);
      // issue kill to all other attempts
      if (task.historyTaskStartGenerated) {
        TaskFinishedEvent tfe = createTaskFinishedEvent(task,
            TaskStateInternal.SUCCEEDED);
        task.eventHandler.handle(new JobHistoryEvent(task.taskId.getJobId(),
            tfe));
      }
      for (TaskAttempt attempt : task.attempts.values()) {
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      eventHandler.handle(new JobTaskAttemptCompletedEvent(tce));
    }
  }

  private static TaskFinishedEvent createTaskFinishedEvent(TaskImpl task, TaskStateInternal taskState) {
    TaskFinishedEvent tfe =
      new TaskFinishedEvent(TypeConverter.fromYarn(task.taskId),
        TypeConverter.fromYarn(task.successfulAttempt),
        task.getFinishTime(task.successfulAttempt),
        TypeConverter.fromYarn(task.taskId.getTaskType()),
        taskState.toString(),
        task.getCounters());
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

     
      jobHistory.logEvent(rfe,  status.getTaskID().getJobID());
     
    }

    TaskFinishedEvent tfe = new TaskFinishedEvent(tip.getTIPId(),
        tip.getExecFinishTime(), taskType,
        TaskStatus.State.SUCCEEDED.toString(),
        new org.apache.hadoop.mapreduce.Counters(status.getCounters()));
   
    jobHistory.logEvent(tfe, tip.getJob().getJobID());
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      task.eventHandler.handle(new JobTaskEvent(
          task.taskId, TaskState.SUCCEEDED));
      LOG.info("Task succeeded with attempt " + task.successfulAttempt);
      // issue kill to all other attempts
      if (task.historyTaskStartGenerated) {
        TaskFinishedEvent tfe = createTaskFinishedEvent(task,
            TaskState.SUCCEEDED);
        task.eventHandler.handle(new JobHistoryEvent(task.taskId.getJobId(),
            tfe));
      }
      for (TaskAttempt attempt : task.attempts.values()) {
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      eventHandler.handle(new JobTaskAttemptCompletedEvent(tce));
    }
  }

  private static TaskFinishedEvent createTaskFinishedEvent(TaskImpl task, TaskState taskState) {
    TaskFinishedEvent tfe =
      new TaskFinishedEvent(TypeConverter.fromYarn(task.taskId),
        TypeConverter.fromYarn(task.successfulAttempt),
        task.getFinishTime(task.successfulAttempt),
        TypeConverter.fromYarn(task.taskId.getTaskType()),
        taskState.toString(),
        task.getCounters());
View Full Code Here

Examples of org.apache.hadoop.mapreduce.jobhistory.TaskFinishedEvent

      eventHandler.handle(new JobTaskAttemptCompletedEvent(tce));
    }
  }

  private static TaskFinishedEvent createTaskFinishedEvent(TaskImpl task, TaskState taskState) {
    TaskFinishedEvent tfe =
      new TaskFinishedEvent(TypeConverter.fromYarn(task.taskId),
        TypeConverter.fromYarn(task.successfulAttempt),
        task.getFinishTime(task.successfulAttempt),
        TypeConverter.fromYarn(task.taskId.getTaskType()),
        taskState.toString(),
        task.getCounters());
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.