Package org.apache.hadoop.mapreduce

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


    BasicTableOutputFormat.setOutputPath(job, invIndexTablePath);
    BasicTableOutputFormat.setSchema(job, "count:int, index:map()");
    job.setNumReduceTasks(options.numReducer);

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

  void reduce(Summary sum, Summary delta) {
    sum.lineCount += delta.lineCount;
View Full Code Here


    BasicTableOutputFormat.setOutputPath(job, freqWordTablePath);
    BasicTableOutputFormat.setSchema(job, "count:int");
    job.setNumReduceTasks(1);

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

  void printFreqWords() throws IOException, ParseException {
    LOG.info("Printing the most frequent words");
View Full Code Here

    BasicTableOutputFormat.setSortInfo(job, sortKey);
    System.out.println("in runMR, sortkey: " + sortKey);
    // set map-only job.
    job.setNumReduceTasks(1);
    job.submit();
    job.waitForCompletion( true );
    BasicTableOutputFormat.close( job );
  }

  @Override
  public int run(String[] args) throws Exception {
View Full Code Here

    BasicTableOutputFormat.setStorageInfo(job, zSchema, zStorageHint,
        zSortInfo);
   
    job.setNumReduceTasks(1);
    job.submit();
    job.waitForCompletion( true );
    BasicTableOutputFormat.close( job );
  }

  public int run(String[] args) throws Exception {
    TestMultipleOutputs3TypedApi test = new TestMultipleOutputs3TypedApi();
View Full Code Here

    BasicTableOutputFormat.setSchema(job, "fileName:string, wordPos:int, lineNo:int");

    // set map-only job.
    job.setNumReduceTasks(0);
    job.submit();
    job.waitForCompletion(true);
    BasicTableOutputFormat.close( job );
  }

  /**
   * Count the # of rows of a BasicTable
View Full Code Here

        zSortInfo);

    // set map-only job.
    job.setNumReduceTasks(1);
    job.submit();
    job.waitForCompletion( true );
    BasicTableOutputFormat.close( job );
  }

  @Override
  public int run(String[] args) throws Exception {
View Full Code Here

    ZebraSortInfo zSortInfo = ZebraSortInfo.createZebraSortInfo(sortKey, null);
    BasicTableOutputFormat.setStorageInfo(job, zSchema, zStorageHint,
        zSortInfo);
    job.setNumReduceTasks(1);
    job.submit();
    job.waitForCompletion( true );
    BasicTableOutputFormat.close( job );
  }

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

    // Set it back to replace invalid timestamp (non-numeric) with current
    // system time
    getConf().setLong(TIMESTAMP_CONF_KEY, timstamp);
   
    Job job = createSubmittableJob(getConf(), otherArgs);
    return job.waitForCompletion(true) ? 0 : 1;
  }

  public static void main(String[] args) throws Exception {
    int status = ToolRunner.run(new ImportTsv(), args);
    System.exit(status);
View Full Code Here

    TableMapReduceUtil.addDependencyJars(job.getConfiguration(),
      org.apache.hadoop.hbase.util.Bytes.class);

    TableMapReduceUtil.initCredentials(job);

    job.waitForCompletion(true);
  }

  /*
   * Write input file of offsets-per-client for the mapreduce job.
   * @param c Configuration
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.