Package org.apache.flink.runtime.jobgraph

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


    }
  }
 
  public void cancel() {
    while (true) {
      JobStatus current = state;
     
      if (current == JobStatus.RUNNING || current == JobStatus.CREATED) {
        if (transitionState(current, JobStatus.CANCELLING)) {
          for (ExecutionJobVertex ejv : verticesInCreationOrder) {
            ejv.cancel();
View Full Code Here


    }
  }
 
  public void fail(Throwable t) {
    while (true) {
      JobStatus current = state;
      if (current == JobStatus.FAILED || current == JobStatus.FAILING) {
        return;
      }
      else if (transitionState(current, JobStatus.FAILING, t)) {
        this.failureCause = t;
View Full Code Here

        if (nextPos == verticesInCreationOrder.size()) {
         
          // we are done, transition to the final state
         
          while (true) {
            JobStatus current = this.state;
            if (current == JobStatus.RUNNING && transitionState(current, JobStatus.FINISHED)) {
              break;
            }
            if (current == JobStatus.CANCELLING && transitionState(current, JobStatus.CANCELED)) {
              break;
View Full Code Here

        this.lastProcessedEventSequenceNumber = event.getSequenceNumber();

        // Check if we can exit the loop
        if (event instanceof JobEvent) {
          final JobEvent jobEvent = (JobEvent) event;
          final JobStatus jobStatus = jobEvent.getCurrentJobStatus();
          if (jobStatus == JobStatus.RUNNING) {
            startTimestamp = jobEvent.getTimestamp();
          }
          if (jobStatus == JobStatus.FINISHED) {
            Runtime.getRuntime().removeShutdownHook(this.jobCleanUp);
View Full Code Here

          lastProcessedEventSequenceNumber = event.getSequenceNumber();

          // Check if we can exit the loop
          if (event instanceof JobEvent) {
            final JobEvent jobEvent = (JobEvent) event;
            final JobStatus jobStatus = jobEvent.getCurrentJobStatus();

            switch (jobStatus) {
            case FINISHED:
              throw new IllegalStateException("Job finished successfully");
            case FAILED:
View Full Code Here

         
          long deadline = System.currentTimeMillis() + 60*1000;
          boolean success = false;
         
          while (System.currentTimeMillis() < deadline) {
            JobStatus state = eg.getState();
            if (state == JobStatus.FINISHED) {
              success = true;
              break;
            }
            else if (state == JobStatus.FAILED || state == JobStatus.CANCELED) {
View Full Code Here

         
          long deadline = System.currentTimeMillis() + 60*1000;
          boolean success = false;
         
          while (System.currentTimeMillis() < deadline) {
            JobStatus state = eg.getState();
            if (state == JobStatus.FINISHED) {
              success = true;
              break;
            }
            else if (state == JobStatus.FAILED || state == JobStatus.CANCELED) {
View Full Code Here

      final Iterator<Map.Entry<JobID, RecentJobEvent>> it = this.recentJobs.entrySet().iterator();
      while (it.hasNext()) {

        final Map.Entry<JobID, RecentJobEvent> entry = it.next();
        final JobStatus jobStatus = entry.getValue().getJobStatus();

        // Only remove jobs from the list which have stopped running
        if (jobStatus != JobStatus.FINISHED && jobStatus != JobStatus.CANCELED
          && jobStatus != JobStatus.FAILED) {
          continue;
View Full Code Here

TOP

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

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.