Package org.apache.flink.runtime.instance

Examples of org.apache.flink.runtime.instance.Instance


      JobVertexID jid2 = new JobVertexID();
      JobVertexID jidx = new JobVertexID();
     
      Scheduler scheduler = new Scheduler();
     
      Instance i1 = getRandomInstance(1);
      Instance i2 = getRandomInstance(1);
     
      scheduler.newInstanceAvailable(i2);
      scheduler.newInstanceAvailable(i1);
     
      assertEquals(2, scheduler.getNumberOfAvailableSlots());
View Full Code Here


      JobVertexID jid1 = new JobVertexID();
      JobVertexID jid2 = new JobVertexID();
     
      Scheduler scheduler = new Scheduler();
     
      Instance i1 = getRandomInstance(1);
      Instance i2 = getRandomInstance(1);
     
      scheduler.newInstanceAvailable(i2);
      scheduler.newInstanceAvailable(i1);
     
      assertEquals(2, scheduler.getNumberOfAvailableSlots());
View Full Code Here

      JobVertexID jid1 = new JobVertexID();
      JobVertexID jid2 = new JobVertexID();
     
      Scheduler scheduler = new Scheduler();
     
      Instance i1 = getRandomInstance(1);
      Instance i2 = getRandomInstance(1);
     
      scheduler.newInstanceAvailable(i2);
      scheduler.newInstanceAvailable(i1);
     
      assertEquals(2, scheduler.getNumberOfAvailableSlots());
View Full Code Here

      final JobVertexID jid = new JobVertexID();
     
      // mock taskmanager to simply accept the call
      TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
     
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexNotExecuting(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
View Full Code Here

    try {
      final JobVertexID jid = new JobVertexID();
     
      // mock taskmanager to simply accept the call
      final TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexExecutingSynchronously(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
View Full Code Here

     
      // mock taskmanager to simply accept the call
      TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
     
     
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexExecutingAsynchronously(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
      when(taskManager.submitTask(Matchers.any(TaskDeploymentDescriptor.class))).thenReturn(new TaskOperationResult(vertex.getCurrentExecutionAttempt().getAttemptId(), true));
View Full Code Here

    try {
      final JobVertexID jid = new JobVertexID();
     
      // mock taskmanager to simply accept the call
      final TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexExecutingSynchronously(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
View Full Code Here

    try {
      final JobVertexID jid = new JobVertexID();
     
      // mock taskmanager to simply accept the call
      final TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexExecutingAsynchronously(jid);
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
      when(taskManager.submitTask(Matchers.any(TaskDeploymentDescriptor.class))).thenReturn(new TaskOperationResult(vertex.getCurrentExecutionAttempt().getAttemptId(), false, ERROR_MESSAGE));
View Full Code Here

      final JobVertexID jid = new JobVertexID();
     
      // mock taskmanager to simply accept the call
      TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
     
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexNotExecuting(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
View Full Code Here

      final JobVertexID jid = new JobVertexID();
     
      // mock taskmanager to simply accept the call
      TaskOperationProtocol taskManager = mock(TaskOperationProtocol.class);
     
      final Instance instance = getInstance(taskManager);
      final AllocatedSlot slot = instance.allocateSlot(new JobID());
     
      final ExecutionJobVertex ejv = getJobVertexExecutingTriggered(jid, queue);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
      final ExecutionAttemptID eid = vertex.getCurrentExecutionAttempt().getAttemptId();
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.instance.Instance

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.