Package org.apache.flink.api.common

Examples of org.apache.flink.api.common.JobExecutionResult


      execute(sink);
    }
   
    long endTime = System.currentTimeMillis();
    Map<String, Object> accumulatorResults = AccumulatorHelper.toResultMap(accumulators);
    return new JobExecutionResult(endTime - startTime, accumulatorResults);
  }
View Full Code Here


       
        NepheleJobGraphGenerator jgg = new NepheleJobGraphGenerator();
        JobGraph jobGraph = jgg.compileJobGraph(op);
       
        JobClient jobClient = this.nephele.getJobClient(jobGraph);
        JobExecutionResult result = jobClient.submitJobAndWait();
        return result;
      }
      finally {
        if (shutDownAtEnd) {
          stop();
View Full Code Here

  }
 
  // --------------------------------------------------------------------------------------------
 
  protected int executeProgram(PackagedProgram program, Client client, int parallelism) {
    JobExecutionResult execResult;
    try {
      client.setPrintStatusDuringExecution(true);
      execResult = client.run(program, parallelism, true);
    }
    catch (ProgramInvocationException e) {
      return handleError(e);
    }
    finally {
      program.deleteExtractedLibraries();
    }
   
    // we come here after the job has finished
    if (execResult != null) {
      System.out.println("Job Runtime: " + execResult.getNetRuntime());
      Map<String, Object> accumulatorsResult = execResult.getAllAccumulatorResults();
      if (accumulatorsResult.size() > 0) {
        System.out.println("Accumulator Results: ");
        System.out.println(AccumulatorHelper.getResultsFormated(accumulatorsResult));
      }
    }
View Full Code Here

TOP

Related Classes of org.apache.flink.api.common.JobExecutionResult

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.