Package org.apache.hadoop.mapred.TaskController

Examples of org.apache.hadoop.mapred.TaskController.TaskControllerContext


        TaskRunner taskRunner = jvmToRunningTask.get(jvmId);
        JvmRunner jvmRunner = jvmIdToRunner.get(jvmId);
        Task task = taskRunner.getTaskInProgress().getTask();

        // Initialize task dirs
        TaskControllerContext context =
            new TaskController.TaskControllerContext();
        context.env = jvmRunner.env;
        context.task = task;
        // If we are returning the same task as which the JVM was launched
        // we don't initialize task once again.
View Full Code Here


      public JvmRunner(JvmEnv env, JobID jobId) {
        this.env = env;
        this.jvmId = new JVMId(jobId, isMap, rand.nextInt());
        this.numTasksToRun = env.conf.getNumTasksToExecutePerJvm();

        this.initalContext = new TaskControllerContext();
        initalContext.sleeptimeBeforeSigkill = tracker.getJobConf()
          .getLong(TTConfig.TT_SLEEP_TIME_BEFORE_SIG_KILL,
                   ProcessTree.DEFAULT_SLEEPTIME_BEFORE_SIGKILL);
        LOG.info("In JvmRunner constructed JVM ID: " + jvmId);
      }
View Full Code Here

        //JVM via this method. However when a new task is launched
        //the task being returned has to be initialized.
        TaskRunner taskRunner = jvmToRunningTask.get(jvmId);
        JvmRunner jvmRunner = jvmIdToRunner.get(jvmId);
        Task task = taskRunner.getTaskInProgress().getTask();
        TaskControllerContext context =
          new TaskController.TaskControllerContext();
        context.env = jvmRunner.env;
        context.task = task;
        //If we are returning the same task as which the JVM was launched
        //we don't initialize task once again.
View Full Code Here

        // Post-JVM-exit logs processing. Truncate the logs.
        truncateJVMLogs();
      }

      public void runChild(JvmEnv env) {
        initalContext = new TaskControllerContext();
        try {
          env.vargs.add(Integer.toString(jvmId.getId()));
          //Launch the task controller to run task JVM
          initalContext.task = jvmToRunningTask.get(jvmId).getTask();
          initalContext.env = env;
View Full Code Here

      jvmManager.doStackTrace(tip.getTaskRunner());
    }
  }
 
  public void doStackTrace(String pid) {
    TaskControllerContext context = new TaskControllerContext ();
    context.pid = pid;
    taskController.doStackTrace(context);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.mapred.TaskController.TaskControllerContext

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.