Package org.apache.flink.runtime.client

Examples of org.apache.flink.runtime.client.JobSubmissionResult


      jm = startJobManager(2 * NUM_TASKS);
     
      final GlobalBufferPool bp = ((LocalInstanceManager) jm.getInstanceManager())
          .getTaskManagers()[0].getChannelManager().getGlobalBufferPool();
     
      JobSubmissionResult result = jm.submitJob(jobGraph);

      if (result.getReturnCode() != AbstractJobResult.ReturnCode.SUCCESS) {
        System.out.println(result.getDescription());
      }
      assertEquals(AbstractJobResult.ReturnCode.SUCCESS, result.getReturnCode());
     
      // monitor the execution
      ExecutionGraph eg = jm.getCurrentJobs().get(jobGraph.getJobID());
     
      if (eg != null) {
View Full Code Here


      jm = startJobManager(NUM_TASKS);
     
      final GlobalBufferPool bp = ((LocalInstanceManager) jm.getInstanceManager())
          .getTaskManagers()[0].getChannelManager().getGlobalBufferPool();
     
      JobSubmissionResult result = jm.submitJob(jobGraph);

      if (result.getReturnCode() != AbstractJobResult.ReturnCode.SUCCESS) {
        System.out.println(result.getDescription());
      }
      assertEquals(AbstractJobResult.ReturnCode.SUCCESS, result.getReturnCode());
     
      // monitor the execution
      ExecutionGraph eg = jm.getCurrentJobs().get(jobGraph.getJobID());
     
      if (eg != null) {
View Full Code Here

      cfg.setInteger(ConfigConstants.JOB_MANAGER_DEAD_TASKMANAGER_TIMEOUT_KEY, 3000);
      cfg.setInteger(ConfigConstants.TASK_MANAGER_HEARTBEAT_INTERVAL_KEY, 1000);
     
      jm = startJobManager(2, NUM_TASKS, cfg);
     
      JobSubmissionResult result = jm.submitJob(jobGraph);

      if (result.getReturnCode() != AbstractJobResult.ReturnCode.SUCCESS) {
        System.out.println(result.getDescription());
      }
      assertEquals(AbstractJobResult.ReturnCode.SUCCESS, result.getReturnCode());
     
      // monitor the execution
      ExecutionGraph eg = jm.getCurrentJobs().get(jobGraph.getJobID());
     
      // wait for a bit until all is running, make sure the second attempt does not block
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.client.JobSubmissionResult

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.