Examples of schedule()


Examples of org.springframework.scheduling.concurrent.ThreadPoolTaskScheduler.schedule()

  ArrayList<ProcessCheckTask> processCheckTaskList = (ArrayList<ProcessCheckTask>) context
    .getBean("processCheckTaskList");

  // Schedule the process check tasks
  for (ProcessCheckTask task : processCheckTaskList) {
      ScheduledFuture<?> future = scheduler.schedule(task, new CronTrigger(task.getCron()));
      task.setScheduledFuture(future);
  }

  while (!Thread.interrupted()) {
      try {
View Full Code Here

Examples of org.teiid.dqp.internal.process.ThreadReuseExecutor.schedule()

    }
   
    @Test public void testSchedule() throws Exception {
      ThreadReuseExecutor pool = new ThreadReuseExecutor("test", 5); //$NON-NLS-1$
        final ArrayList<String> result = new ArrayList<String>();
      pool.schedule(new Work() {
     
      @Override
      public void run() {
          result.add("hello"); //$NON-NLS-1$
      }
View Full Code Here

Examples of org.tuba.integration.IntegrationJob.schedule()

    }

    if (doIntegration) {
      IntegrationJob job = new IntegrationJob(document);
      job.setUser(true);
      job.schedule();
      try {
        job.join();
      } catch (InterruptedException e) {
        e.printStackTrace();
      }
View Full Code Here

Examples of org.waveprotocol.wave.client.scheduler.ScheduleTimer.schedule()

      @Override
      public void run() {
        regionNode.getImplNodelet().removeClassName(resources.css().repaired());
      }
    };
    t.schedule(800);
  }

  /**
   * Mark a region (probably everything) as not recoverable
   * @param regionNode
View Full Code Here

Examples of org.xtext.builddsl.ui.launch.RefreshJob.schedule()

                boolean _equals_1 = Objects.equal(configuration, _launchConfiguration);
                if (_equals_1) {
                  DebugPlugin _default = DebugPlugin.getDefault();
                  _default.removeDebugEventListener(this);
                  RefreshJob _refreshJob = new RefreshJob(configuration);
                  _refreshJob.schedule();
                  return;
                }
              }
            }
          }
View Full Code Here

Examples of rx.Scheduler.Worker.schedule()

    }

    public static <T> HystrixFuture<T> from(final Action1<Promise<T>> action, Scheduler s) {
        final Promise<T> p = Promise.create();
        final Worker worker = s.createWorker();
        worker.schedule(new Action0() {

            @Override
            public void call() {
                try {
                    action.call(p);
View Full Code Here

Examples of tool.builder.RepositoryStateJob.schedule()

  private void syncrohizeRepositoryState() {
   
    RepositoryStateJob runner = new RepositoryStateJob();
    runner.setPriority(Job.LONG);
    runner.schedule();
  }

  /*
   * (non-Javadoc)
   * @see org.eclipse.ui.plugin.AbstractUIPlugin#stop(org.osgi.framework.BundleContext)
View Full Code Here

Examples of voldemort.common.service.SchedulerService.schedule()

                                                                                SystemTime.INSTANCE,
                                                                                new EventThrottler(1),
                                                                                null);

            // and will run every 5 seconds starting now
            scheduler.schedule("cleanup-freq-test", cleanupJob, now, 5 * Time.MS_PER_SECOND);

            // load some data
            for(int i = 0; i < 10; i++) {
                ByteArray b = new ByteArray(Integer.toString(i).getBytes());
                engine.put(b, new Versioned<byte[]>(b.get()), null);
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.