Package org.apache.flink.runtime.jobgraph

Examples of org.apache.flink.runtime.jobgraph.JobID


  public void testRunJobWithForwardChannel() {
    JobManager jobManager = null;
    TaskManager tm = null;

    try {
      JobID jid = new JobID();
     
      JobVertexID vid1 = new JobVertexID();
      JobVertexID vid2 = new JobVertexID();
     
      ExecutionAttemptID eid1 = new ExecutionAttemptID();
View Full Code Here


    JobManager jobManager = null;
    TaskManager tm = null;

    try {
      JobID jid = new JobID();
     
      JobVertexID vid1 = new JobVertexID();
      JobVertexID vid2 = new JobVertexID();
     
      ExecutionAttemptID eid1 = new ExecutionAttemptID();
View Full Code Here

    }
  }

  @Test
  public void testFileReuseForNextTask() {
    JobID jobID = new JobID();
    String filePath = f.toURI().toString();
    fileCache.createTmpFile("test_file", new DistributedCacheEntry(filePath, false), jobID);
    try {
      Thread.sleep(1000);
    } catch (InterruptedException e) {
View Full Code Here

    if (printHelp) {
      printHelpForCancel();
      return 0;
    }
   
    JobID jobId;
   
    if (line.hasOption(ID_OPTION.getOpt())) {
      String jobIdString = line.getOptionValue(ID_OPTION.getOpt());
      try {
        jobId = new JobID(StringUtils.hexStringToByte(jobIdString));
      } catch (Exception e) {
        System.out.println("Error: The value for the Job ID is not a valid ID.");
        printHelpForCancel();
        return 1;
      }
View Full Code Here

      sender.setInvokableClass(NoOpInvokable.class);
      sender.setParallelism(NUM_TASKS);
     
      final JobGraph jobGraph = new JobGraph("Pointwise Job", sender);
     
      ExecutionGraph eg = new ExecutionGraph(new JobID(), "test job", new Configuration());
      eg.setNumberOfRetriesLeft(0);
      eg.attachJobGraph(jobGraph.getVerticesSortedTopologicallyFromSources());
     
      assertEquals(JobStatus.CREATED, eg.getState());
     
View Full Code Here

      sender.setInvokableClass(NoOpInvokable.class);
      sender.setParallelism(NUM_TASKS);
     
      final JobGraph jobGraph = new JobGraph("Pointwise Job", sender);
     
      ExecutionGraph eg = new ExecutionGraph(new JobID(), "test job", new Configuration());
      eg.setNumberOfRetriesLeft(1);
      eg.attachJobGraph(jobGraph.getVerticesSortedTopologicallyFromSources());
     
      assertEquals(JobStatus.CREATED, eg.getState());
     
View Full Code Here

      v4.setSlotSharingGroup(jg2);
      v5.setSlotSharingGroup(jg2);
     
      List<AbstractJobVertex> vertices = new ArrayList<AbstractJobVertex>(Arrays.asList(v1, v2, v3, v4, v5));
     
      ExecutionGraph eg = new ExecutionGraph(new JobID(), "test job", new Configuration());
      eg.attachJobGraph(vertices);
     
      // verify that the vertices are all in the same slot sharing group
      SlotSharingGroup group1 = null;
      SlotSharingGroup group2 = null;
View Full Code Here

      sender.setInvokableClass(NoOpInvokable.class);
      sender.setParallelism(20);
     
      final JobGraph jobGraph = new JobGraph("Pointwise Job", sender);
     
      ExecutionGraph eg = new ExecutionGraph(new JobID(), "test job", new Configuration());
      eg.setNumberOfRetriesLeft(0);
      eg.attachJobGraph(jobGraph.getVerticesSortedTopologicallyFromSources());
     
     
      assertEquals(JobStatus.CREATED, eg.getState());
View Full Code Here

  }
 
  @Override
  public void jobStatusHasChanged(ExecutionGraph executionGraph, JobStatus newJobStatus, String optionalMessage) {

    final JobID jid = executionGraph.getJobID();
   
    if (LOG.isInfoEnabled()) {
      String message = optionalMessage == null ? "." : ": " + optionalMessage;
      LOG.info(String.format("Job %s (%s) switched to %s%s",
          jid, executionGraph.getJobName(), newJobStatus, message));
View Full Code Here

   
    try {
      // a slot than cannot be deployed to
      final TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
      slot.cancel();
      assertFalse(slot.isReleased());
     
      final ExecutionJobVertex ejv = getJobVertexNotExecuting(new JobVertexID());
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.jobgraph.JobID

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.