Examples of JobState


Examples of com.facebook.presto.importer.JobStateFactory.JobState

                for (Long jobId : jobsToAdd) {
                    runningJobs.put(jobId, jobStateFactory.forImportJob(configuredJobs.get(jobId)));
                }

                for (Long oldJob : jobsToRemove) {
                    JobState removedJob = runningJobs.remove(oldJob);
                    removedJob.cancel(true);
                }

                log.debug("Current set of jobs is %s", runningJobs.keySet());

                for (JobState importJob : runningJobs.values()) {
View Full Code Here

Examples of com.microsoft.windowsazure.scheduler.models.JobState

                    }
                }
               
                JsonNode stateValue = responseDoc.get("state");
                if (stateValue != null) {
                    JobState stateInstance;
                    stateInstance = SchedulerClientImpl.parseJobState(stateValue.getTextValue());
                    jobInstance.setState(stateInstance);
                }
            }
           
View Full Code Here

Examples of com.microsoft.windowsazure.services.media.models.JobState

    public void createJobSuccess() throws ServiceException {
        // Arrange
        String name = testJobPrefix + "createJobSuccess";
        int priority = 3;
        double duration = 0.0;
        JobState state = JobState.Queued;
        String templateId = null;
        Date created = new Date();
        Date lastModified = new Date();
        Date stateTime = null;
        Date endTime = null;
View Full Code Here

Examples of org.apache.airavata.model.workspace.experiment.JobState

        ObjectMapper objectMapper = new ObjectMapper();
        try {
            ComputingActivity computingActivity = objectMapper.readValue(message.getBytes(), ComputingActivity.class);
            logger.info(computingActivity.getIDFromEndpoint());
            List<String> stateList = computingActivity.getState();
            JobState jobState = null;
            for (String aState : stateList) {
                jobState = getStatusFromString(aState);
            }
            // we get the last value of the state array
            return jobState;
View Full Code Here

Examples of org.apache.hadoop.mapreduce.v2.api.records.JobState

  @Override
  public JobReport getReport() {
    readLock.lock();
    try {
      JobState state = getState();

      // jobFile can be null if the job is not yet inited.
      String jobFile =
          remoteJobConfFile == null ? "" : remoteJobConfFile.toString();
View Full Code Here

Examples of org.apache.hadoop.mapreduce.v2.api.records.JobState

  @Override
  public JobState getState() {
    readLock.lock();
    try {
      JobState state = getExternalState(getInternalState());
      if (!appContext.hasSuccessfullyUnregistered()
          && (state == JobState.SUCCEEDED || state == JobState.FAILED
          || state == JobState.KILLED || state == JobState.ERROR)) {
        return lastNonFinalState;
      } else {
View Full Code Here

Examples of org.apache.hadoop.mapreduce.v2.api.records.JobState

      writeLock.unlock();
    }
  }

  private void rememberLastNonFinalState(JobStateInternal stateInternal) {
    JobState state = getExternalState(stateInternal);
    // if state is not the final state, set lastNonFinalState
    if (state != JobState.SUCCEEDED && state != JobState.FAILED
        && state != JobState.KILLED && state != JobState.ERROR) {
      lastNonFinalState = state;
    }
View Full Code Here

Examples of org.apache.hadoop.mapreduce.v2.api.records.JobState

  @Override
  public JobReport getReport() {
    readLock.lock();
    try {
      JobState state = getState();

      // jobFile can be null if the job is not yet inited.
      String jobFile =
          remoteJobConfFile == null ? "" : remoteJobConfFile.toString();
View Full Code Here

Examples of org.apache.hadoop.mapreduce.v2.api.records.JobState

  public Counters getAllCounters() {

    readLock.lock();

    try {
      JobState state = getState();
      if (state == JobState.ERROR || state == JobState.FAILED
          || state == JobState.KILLED || state == JobState.SUCCEEDED) {
        this.mayBeConstructFinalFullCounters();
        return fullCounters;
      }
View Full Code Here

Examples of org.apache.hadoop.mapreduce.v2.api.records.JobState

  @Override
  public JobReport getReport() {
    readLock.lock();
    try {
      JobState state = getState();

      // jobFile can be null if the job is not yet inited.
      String jobFile =
          remoteJobConfFile == null ? "" : remoteJobConfFile.toString();
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.