Package org.apache.flink.runtime.jobgraph

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


   * to be called directly.
   */
  public VertexEvent() {
    super();

    this.jobVertexID = new JobVertexID();
    this.totalNumberOfSubtasks = -1;
    this.indexOfSubtask = -1;
    this.executionAttemptId = new ExecutionAttemptID();
    this.currentExecutionState = ExecutionState.CREATED;
  }
View Full Code Here


   * to be called directly.
   */
  public ExecutionStateChangeEvent() {
    super();

    this.vertexId = new JobVertexID();
    this.executionAttemptId = new ExecutionAttemptID();
    this.newExecutionState = ExecutionState.CREATED;
  }
View Full Code Here

    this.profilingInterval = profilingInterval;
  }

  public VertexProfilingEvent() {
    super();
    this.vertexId = new JobVertexID();
    this.executionId = new ExecutionAttemptID();
  }
View Full Code Here

  private final ExecutionAttemptID executionId;

 
  public InternalExecutionVertexProfilingData() {
    this.jobId = new JobID();
    this.vertexId = new JobVertexID();
    this.executionId = new ExecutionAttemptID();
    this.subtask = -1;
  }
View Full Code Here

   */
  @Test
  public void testThreadProfilingEvent() {

    final ThreadProfilingEvent orig = new ThreadProfilingEvent(USER_TIME, SYSTEM_TIME, BLOCKED_TIME, WAITED_TIME,
      new JobVertexID(), 17, new ExecutionAttemptID(), PROFILING_INTERVAL, new JobID(), TIMESTAMP, PROFILING_TIMESTAMP);

    final ThreadProfilingEvent copy = (ThreadProfilingEvent) ManagementTestUtils.createCopy(orig);

    assertEquals(orig.getUserTime(), copy.getUserTime());
    assertEquals(orig.getSystemTime(), copy.getSystemTime());
View Full Code Here


  @Override
  public TaskOperationResult submitTask(TaskDeploymentDescriptor tdd) {
    final JobID jobID = tdd.getJobID();
    final JobVertexID vertexId = tdd.getVertexID();
    final ExecutionAttemptID executionId = tdd.getExecutionId();
    final int taskIndex = tdd.getIndexInSubtaskGroup();
    final int numSubtasks = tdd.getCurrentNumberOfSubtasks();
   
    Task task = null;
View Full Code Here

    return null;
  }

  @Override
  public JobVertexID getJobVertexId() {
    return new JobVertexID(new byte[16]);
  }
View Full Code Here

  // --------------------------------------------------------------------------------------------
 
  @Test
  public void testCancelFromCreated() {
    try {
      final JobVertexID jid = new JobVertexID();
      final ExecutionJobVertex ejv = getJobVertexNotExecuting(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
      assertEquals(ExecutionState.CREATED, vertex.getExecutionState());
View Full Code Here

  }
 
  @Test
  public void testCancelFromScheduled() {
    try {
      final JobVertexID jid = new JobVertexID();
      final ExecutionJobVertex ejv = getJobVertexNotExecuting(jid);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
     
      setVertexState(vertex, ExecutionState.SCHEDULED);
View Full Code Here

  }
 
  @Test
  public void testCancelConcurrentlyToDeploying_CallsNotOvertaking() {
    try {
      final JobVertexID jid = new JobVertexID();
      final ActionQueue actions = new ActionQueue();
     
      final ExecutionJobVertex ejv = getJobVertexExecutingTriggered(jid, actions);
     
      final ExecutionVertex vertex = new ExecutionVertex(ejv, 0, new IntermediateResult[0]);
View Full Code Here

TOP

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

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.