Package org.apache.flink.runtime.executiongraph

Examples of org.apache.flink.runtime.executiongraph.ExecutionAttemptID


    super();

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


   */
  public ExecutionStateChangeEvent() {
    super();

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

  }

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

 
  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

  /**
   * Creates an empty task execution state.
   */
  public TaskExecutionState() {
    this.jobID = new JobID();
    this.executionId = new ExecutionAttemptID();
  }
View Full Code Here

 
  private String description;


  public TaskOperationResult() {
    this(new ExecutionAttemptID(), false);
  }
View Full Code Here

    try {
     
      // ExecutionStateChangeEvent
      {
        JobVertexID jid = new JobVertexID();
        ExecutionAttemptID eid = new ExecutionAttemptID();
       
        ExecutionStateChangeEvent e1 = new ExecutionStateChangeEvent(429345231796596L, jid, 17, eid, ExecutionState.CANCELING);
        ExecutionStateChangeEvent e2 = new ExecutionStateChangeEvent(429345231796596L, jid, 17, eid, ExecutionState.CANCELING);
       
        assertTrue(e1.equals(e2));
        assertEquals(e1.hashCode(), e2.hashCode());
        e1.toString();
      }
     
      // JobEvent
      {
        JobEvent e1 = new JobEvent(429345231796596L, JobStatus.CANCELED, "testmessage");
        JobEvent e2 = new JobEvent(429345231796596L, JobStatus.CANCELED, "testmessage");
        JobEvent e3 = new JobEvent(237217579123412431L, JobStatus.RUNNING, null);
        JobEvent e4 = new JobEvent(237217579123412431L, JobStatus.RUNNING, null);
       
        assertTrue(e1.equals(e2));
        assertTrue(e3.equals(e4));
       
        assertEquals(e1.hashCode(), e2.hashCode());
        assertEquals(e3.hashCode(), e4.hashCode());
        e1.toString();
        e3.toString();
      }
     
      // RecentJobEvent
      {
        JobID jid = new JobID();
        RecentJobEvent e1 = new RecentJobEvent(jid, "some name", JobStatus.FAILED, false, 634563546, 546734734672572457L);
        RecentJobEvent e2 = new RecentJobEvent(jid, "some name", JobStatus.FAILED, false, 634563546, 546734734672572457L);
        RecentJobEvent e3 = new RecentJobEvent(jid, null, JobStatus.RUNNING, false, 42364716239476L, 127843618273607L);
        RecentJobEvent e4 = new RecentJobEvent(jid, null, JobStatus.RUNNING, false, 42364716239476L, 127843618273607L);
       
        assertTrue(e1.equals(e2));
        assertTrue(e3.equals(e4));
       
        assertEquals(e1.hashCode(), e2.hashCode());
        assertEquals(e3.hashCode(), e4.hashCode());
        e1.toString();
        e3.toString();
      }
     
      // VertexEvent
      {
        JobVertexID jid = new JobVertexID();
        ExecutionAttemptID eid = new ExecutionAttemptID();
       
        VertexEvent e1 = new VertexEvent(64619276017401234L, jid, "peter", 44, 13, eid, ExecutionState.DEPLOYING, "foo");
        VertexEvent e2 = new VertexEvent(64619276017401234L, jid, "peter", 44, 13, eid, ExecutionState.DEPLOYING, "foo");
       
        VertexEvent e3 = new VertexEvent(64619276017401234L, jid, null, 44, 13, eid, ExecutionState.DEPLOYING, null);
View Full Code Here

  @Test
  public void testSerialization() {
    try {
      JobID jid = new JobID();
      JobVertexID vid = new JobVertexID();
      ExecutionAttemptID eid = new ExecutionAttemptID();
     
      ExecutionStateChangeEvent esce = new ExecutionStateChangeEvent(429345231796596L, vid, 17, eid, ExecutionState.CANCELING);

      JobEvent je1 = new JobEvent(429345231796596L, JobStatus.CANCELED, "testmessage");
      JobEvent je2 = new JobEvent(237217579123412431L, JobStatus.RUNNING, null);
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.executiongraph.ExecutionAttemptID

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.