Examples of Job


Examples of au.org.aodn.reefscenarios.entities.Job

        try
        {
            ProcessRunner runner = new ProcessRunner();

            Job j = new Job();
            j.setJobName("blah");
            j.setJobPath(System.getProperty("user.dir") + "/src/test");
            System.out.println("job path: " + j.createRunPath());
            User user = new User();
            user.setEmailAddress("pauline.mak@utas.edu.au");

            j.setUserId(user.getUserId());
            runner.submitJob(j);

            System.out.println("new PBS job name: " + j.getPBSJobName());

            Assert.assertEquals(j.getPBSJobName(), "62586");
        }
        catch(Exception e)
        {
            System.out.println("This should NEVER HAPPEN!");
            e.printStackTrace();
View Full Code Here

Examples of azkaban.common.jobs.Job

        // Check if we have already loaded this job
        if(loadedJobs.containsKey(jobName))
            return loadedJobs.get(jobName);

        Job job = _factory.apply(desc);

        if(ignoreDependencies || !desc.hasDependencies()) {
            loadedJobs.put(jobName, job);
            return job;
        } else {
View Full Code Here

Examples of beans.user.job.entity.Job

       
        List jobs = findEntityList(Job.class, "client", entity, "ORDER BY a.begin");
        List<JobDetails> res = new ArrayList<JobDetails>();
        Iterator i = jobs.iterator();
        while (i.hasNext()) {
            Job j = (Job) i.next();
            res.add(j.getDetails((RightChecker) this));
        }
        return res;
    }
View Full Code Here

Examples of bitronix.tm.twopc.executor.Job

            if (!isParticipating(resourceHolderState)) {
                if (log.isDebugEnabled()) log.debug("skipping not participating resource " + resourceHolderState);
                continue;
            }

            Job job = createJob(resourceHolderState);
            Object future = executor.submit(job);
            job.setFuture(future);
            jobs.add(job);
        }

        // wait for threads to finish and check results
        for (int i = 0; i < jobs.size(); i++) {
            Job job = (Job) jobs.get(i);

            Object future = job.getFuture();
            while (!executor.isDone(future)) {
                executor.waitFor(future, 1000L);
            }

            XAException xaException = job.getXAException();
            RuntimeException runtimeException = job.getRuntimeException();

            if (xaException != null) {
                if (log.isDebugEnabled()) log.debug("error executing " + job + ", errorCode=" + Decoder.decodeXAExceptionErrorCode(xaException));
                exceptions.add(xaException);
                errorResources.add(job.getResource());
            } else if (runtimeException != null) {
                if (log.isDebugEnabled()) log.debug("error executing " + job);
                exceptions.add(runtimeException);
                errorResources.add(job.getResource());
            }
        }

        if (log.isDebugEnabled()) log.debug("phase executed with " + exceptions.size() + " exception(s)");
        return new JobsExecutionReport(exceptions, errorResources);
View Full Code Here

Examples of ch.ethz.vs.rowa.job.Job

  /*
   * add a waiting job for client uuid to the running list
   */
  public void addWaitingJob(UUID uuid){
   
    Job job;
    synchronized (waitingJobList) {
      ClientRequests crequest = waitingJobList.get(uuid);
      //System.out.println("addwaitingjob -> "+crequest.getSizeOfJob());
      if(crequest.getSizeOfJob() > 0){
       
View Full Code Here

Examples of com.acelet.s.job.Job

  throws Exception {
    if (isDesired(comingChore) == false)
      return false;

    Hashtable nameToChoreHashtable = (Hashtable) Registry.nameToChoreHashtable.clone();
    Job job = new CreateJob().createJob(comingChore, nameToChoreHashtable);
    TimerTask timerTask = new CommonTimerTask(comingChore, job, triggering);

    Timer timer = new Timer();
    timer.schedule(timerTask, comingChore.delay);
   
View Full Code Here

Examples of com.appspot.piment.model.Job

  public void doGet(HttpServletRequest req, HttpServletResponse resp) {
  log.info("-- Job1009 start --");

  long startTime = System.currentTimeMillis();
  Job job = null;
  try {

    job = (new JobDao()).getJob(this.getClass().getName());

    job.setStatus(JobStatus.RUNNING);
    PMF.saveEntity(job);
    log.info("job's status:" + job);

    // トークン情報の削除
    AuthTokenDao authTokenDao = new AuthTokenDao();
    authTokenDao.clearTempToken(Integer.valueOf(this.configMap.get("app.piment.temptoken.lifetime")));

    UserMapDao userMapDao = new UserMapDao();
    List<UserMap> allUserMap = userMapDao.getAllUserMaps();

    // メッセージ履歴の掃除
    WeiboMapDao weiboMapDao = new WeiboMapDao();
    weiboMapDao.removeOlder(allUserMap, Integer.valueOf(this.configMap.get("app.piment.weibomap.lifetime")));

    // コメント履歴の掃除
    CommentMapDao commentMapDao = new CommentMapDao();
    commentMapDao.removeOlder(allUserMap, Integer.valueOf(this.configMap.get("app.piment.weibomap.lifetime")));

    // ジョブ状態変更
    job.setStatus(JobStatus.SUCCESSED);

  } catch (Exception e) {
    // ジョブ状態変更
    if (job != null) {
    job.setStatus(JobStatus.FAILED);
    }
    throw new RuntimeException(e);
  } finally {

    long costTime = System.currentTimeMillis() - startTime;
    if (job != null) {
    job.setLastExecuteTime(DateUtils.getSysDate());
    job.setCostTime(costTime);
    PMF.saveEntity(job);
    log.info("job's status:" + job);
    }
    log.info("-- Job1009 end [cost " + costTime + " TimeMillis]--");
  }
View Full Code Here

Examples of com.asakusafw.testdriver.TestExecutionPlan.Job

        assert info != null;
        assert commands != null;
        assert properties != null;
        List<Job> jobs = Lists.create();
        for (StageInfo stage : info.getStages()) {
            jobs.add(new Job(stage.getClassName(), commands.getExecutionId(), properties));
        }

        List<Command> initializers = Lists.create();
        List<Command> importers = Lists.create();
        List<Command> exporters = Lists.create();
View Full Code Here

Examples of com.asakusafw.yaess.core.Job

        }

        private boolean submitAllWaiting() throws IOException, InterruptedException {
            boolean sawSubmit = false;
            for (Iterator<Job> iter = waiting.iterator(); iter.hasNext();) {
                Job next = iter.next();
                LOG.debug("Attemps to submit job: {}", next.getId());
                if (isBlocked(next)) {
                    LOG.debug("Job is currently blocked: {}", next.getId());
                    continue;
                }
                iter.remove();
                if (submit(next)) {
                    sawSubmit = true;
View Full Code Here

Examples of com.cin.entity.Job

      update(ejb);
    }
  }
  public void updateUserJob(UserDTO user)
  {
    Job ejb = manager.find(Job.class, user.getSsn());
    if( ejb == null )
    {
      ejb = user.getJobDetails().toEJB(user.getSsn());
      persist(ejb);
    } else {
      Industry ind = new Industry();
      Occupation occ = new Occupation();
      ind.setIndustrycode(user.getJobDetails().getIndustryCode());
      occ.setOccupationcode(user.getJobDetails().getOccupationCode());
      ejb.setEmployersize(user.getJobDetails().getEmployerSize());
      ejb.setIndustry(ind);
      ejb.setOccupation(occ);
      ejb.setSelfemployed(user.getJobDetails().getSelfEmployed());
      ejb.setUnionmember(user.getJobDetails().getUnionMember());
      ejb.setWeekwage(user.getJobDetails().getWeekWage());
      ejb.setWorkclass(user.getJobDetails().getWorkClass());
      ejb.setWorkweeks(user.getJobDetails().getWorkWeeks());

      update(ejb);
    }
  }
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.