Package org.apache.hadoop.mapreduce.lib.jobcontrol

Examples of org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob


    Job countingJob = getCountingJob(postInput, countingOutput);

    int code = 1;
    if (countingJob.waitForCompletion(true)) {
      ControlledJob binningControlledJob = new ControlledJob(
          getBinningJobConf(countingJob, countingOutput, userInput,
              binningOutputRoot));

      ControlledJob belowAvgControlledJob = new ControlledJob(
          getAverageJobConf(binningOutputBelow, belowAverageRepOutput));
      belowAvgControlledJob.addDependingJob(binningControlledJob);

      ControlledJob aboveAvgControlledJob = new ControlledJob(
          getAverageJobConf(binningOutputAbove, aboveAverageRepOutput));
      aboveAvgControlledJob.addDependingJob(binningControlledJob);

      JobControl jc = new JobControl("AverageReputation");
      jc.addJob(binningControlledJob);
      jc.addJob(belowAvgControlledJob);
      jc.addJob(aboveAvgControlledJob);
View Full Code Here


          Iterator<ControlledJob> it = getJobs(jobsInProgress).iterator();
          if (!it.hasNext()) {
              stop();
          }
          while(it.hasNext()) {
            ControlledJob j = it.next();
            log.debug("Checking state of job "+j);
            switch(checkState(j)) {
            case SUCCESS:
              getJobs(successfulJobs).add(j);
              it.remove();
View Full Code Here

        }

        synchronized(this) {
          Iterator<ControlledJob> it = getJobs(jobsInProgress).iterator();
          while(it.hasNext()) {
            ControlledJob j = it.next();
            log.debug("Checking state of job "+j);
            switch(checkState(j)) {
            case SUCCESS:
              getJobs(successfulJobs).add(j);
              it.remove();
View Full Code Here

    Configuration conf = new Configuration();
    if (descriptors != null) {
      conf = setAggregatorDescriptors(descriptors);
    }
    Job job = createValueAggregatorJob(conf, args);
    ControlledJob cjob = new ControlledJob(job, dependingJobs);
    theControl.addJob(cjob);
    return theControl;
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.mapreduce.lib.jobcontrol.ControlledJob

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.