Package org.apache.hadoop.mapreduce

Examples of org.apache.hadoop.mapreduce.Job.waitForCompletion()


    job.setMapperClass(ParallelFPGrowthMapper.class);
    job.setCombinerClass(ParallelFPGrowthCombiner.class);
    job.setReducerClass(ParallelFPGrowthReducer.class);
    job.setOutputFormatClass(SequenceFileOutputFormat.class);
   
    job.waitForCompletion(true);
  }
 
  /**
   * Serializes the fList and returns the string representation of the List
   *
 
View Full Code Here


   
    job.setInputFormatClass(TextInputFormat.class);
    job.setOutputFormatClass(SequenceFileOutputFormat.class);
   
    // run the job
    job.waitForCompletion(true);
   
    int[][] counts = parseOutput(job);
   
    // delete the output path
    fs.delete(outputPath, true);
View Full Code Here

    job.setMapperClass(KeyBasedStringTupleMapper.class);
    job.setCombinerClass(KeyBasedStringTupleCombiner.class);
    job.setReducerClass(KeyBasedStringTupleReducer.class);
    job.setOutputFormatClass(TextOutputFormat.class);
   
    job.waitForCompletion(true);
  }
}
View Full Code Here

    job.setNumReduceTasks(numReducers);
    job.setOutputFormatClass(SequenceFileOutputFormat.class);
    job.setInputFormatClass(SequenceFileInputFormat.class);
    job.setJarByClass(LDADriver.class);
   
    job.waitForCompletion(true);
    return findLL(stateOut, conf);
  }
 
  static LDAState createState(Configuration job) throws IOException {
    String statePath = job.get(STATE_IN_KEY);
View Full Code Here

  @Override
  public int run(String[] args) throws Exception {
    String[] otherArgs = new GenericOptionsParser(getConf(), args).getRemainingArgs();
    Job job = createSubmittableJob(getConf(), otherArgs);
    if (job == null) return 1;
    return job.waitForCompletion(true) ? 0 : 1;
  }
}
View Full Code Here

      LOG.debug("Add Input Path=" + path);
      SequenceFileInputFormat.addInputPath(job, path);
    }

    // Run the MR Job
    if (!job.waitForCompletion(true)) {
      // TODO: Replace the fixed string with job.getStatus().getFailureInfo()
      // when it will be available on all the supported versions.
      throw new ExportSnapshotException("Copy Files Map-Reduce Job failed");
    }
  }
View Full Code Here

    // system time
    conf.setLong(TIMESTAMP_CONF_KEY, timstamp);
   
    hbaseAdmin = new HBaseAdmin(conf);
    Job job = createSubmittableJob(conf, otherArgs);
    System.exit(job.waitForCompletion(true) ? 0 : 1);
  }

}
View Full Code Here

    }
    Job job = createSubmittableJob(conf, otherArgs);
    if (job == null) {
      System.exit(-1);
    }
    System.exit(job.waitForCompletion(true) ? 0 : 1);
  }
}
View Full Code Here

      // Initialize credential for secure cluster
      TableMapReduceUtil.initCredentials(job);

      // Start the MR Job and wait
      return job.waitForCompletion(true) ? 0 : 1;
    } finally {
      fs.delete(stagingDir, true);
    }
  }
View Full Code Here

        zSortInfo);
    System.out.println("in runMR, sortkey: " + sortKey);

    job.setNumReduceTasks(1);
    job.submit();
    job.waitForCompletion( true );
    BasicTableOutputFormat.close( job );
  }

  @Override
  public int run(String[] args) throws Exception {
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.