Package org.apache.flink.runtime.execution

Examples of org.apache.flink.runtime.execution.ExecutionState


      // it can mean:
      //  - canceling, while deployment was in progress. state is now canceling, or canceled, if the response overtook
      //  - finishing (execution and finished call overtook the deployment answer, which is possible and happens for fast tasks)
      //  - failed (execution, failure, and failure message overtook the deployment answer)
     
      ExecutionState currentState = this.state;
     
      if (currentState == FINISHED || currentState == CANCELED) {
        // do nothing, the task was really fast (nice)
        // or it was canceled really fast
      }
View Full Code Here


  // --------------------------------------------------------------------------------------------
 
  public void resetForNewExecution() {
    synchronized (priorExecutions) {
      Execution execution = currentExecution;
      ExecutionState state = execution.getState();
     
      if (state == FINISHED || state == CANCELED || state == FAILED) {
        priorExecutions.add(execution);
        currentExecution = new Execution(this, execution.getAttemptNumber()+1, System.currentTimeMillis());
       
View Full Code Here

  @Test
  public void testEqualsHashCode() {
    try {
      final JobID jid = new JobID();
      final ExecutionAttemptID executionId = new ExecutionAttemptID();
      final ExecutionState state = ExecutionState.RUNNING;
      final Throwable error = new RuntimeException("some test error message");
     
      TaskExecutionState s1 = new TaskExecutionState(jid, executionId, state, error);
      TaskExecutionState s2 = new TaskExecutionState(jid, executionId, state, error);
     
View Full Code Here

  @Test
  public void testSerialization() {
    try {
      final JobID jid = new JobID();
      final ExecutionAttemptID executionId = new ExecutionAttemptID();
      final ExecutionState state = ExecutionState.DEPLOYING;
      final Throwable error = new IOException("fubar");
     
      TaskExecutionState original1 = new TaskExecutionState(jid, executionId, state, error);
      TaskExecutionState original2 = new TaskExecutionState(jid, executionId, state);
     
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.execution.ExecutionState

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.