Examples of Scheduler


Examples of org.apache.ace.agent.scheduler.impl.Scheduler

    @Override
    public void init(BundleContext context, DependencyManager manager) throws Exception {

        Properties properties = new Properties();
        m_scheduler = new Scheduler();
        manager.add(createComponent()
            .setImplementation(m_scheduler)
            .add(createServiceDependency()
                .setService(LogService.class).setRequired(false))
            .add(createServiceDependency()
View Full Code Here

Examples of org.apache.activemq.thread.Scheduler

        this.stats = new JMSConnectionStatsImpl(sessions, this instanceof XAConnection);
        this.factoryStats.addConnection(this);
        this.timeCreated = System.currentTimeMillis();
        this.connectionAudit.setCheckForDuplicates(transport.isFaultTolerant());
        this.scheduler = new Scheduler("ActiveMQConnection["+uniqueId+"] Scheduler");
        this.scheduler.start();
    }
View Full Code Here

Examples of org.apache.airavata.core.gfac.scheduler.Scheduler

        log.debug("After preprocess, try to get Scheduler and schedule");

        /*
         * Determine provider
         */
        Scheduler scheduler = getScheduler(context);
        context.getExecutionContext().getNotifier().startSchedule(context);
        Provider provider = scheduler.schedule(context);
        context.getExecutionContext().getNotifier().finishSchedule(context);

        log.debug("After scheduling, try to run data chain");

        /*
 
View Full Code Here

Examples of org.apache.axis2.deployment.scheduler.Scheduler

     * Starts the Deployment engine to perform Hot deployment and so on.
     *
     * @param listener : RepositoryListener
     */
    protected void startSearch(RepositoryListener listener) {
        scheduler = new Scheduler();

        schedulerTask = new SchedulerTask(listener, axisConfig);
        scheduler.schedule(schedulerTask, new DeploymentIterator());
    }
View Full Code Here

Examples of org.apache.flink.runtime.jobmanager.scheduler.Scheduler

     
      // 1)
      // scheduling after being created should be tolerated (no exception) because
      // it can occur as the result of races
      {
        Scheduler scheduler = mock(Scheduler.class);
        vertex.scheduleForExecution(scheduler, false);
       
        assertEquals(ExecutionState.CANCELED, vertex.getExecutionState());
      }
     
View Full Code Here

Examples of org.apache.hadoop.lib.service.Scheduler

      @Override
      public Long getValue() {
        return (long) unmanagedFileSystems.get();
      }
    });
    Scheduler scheduler = getServer().get(Scheduler.class);
    int purgeInterval = getServiceConfig().getInt(FS_CACHE_PURGE_FREQUENCY, 60);
    purgeTimeout = getServiceConfig().getLong(FS_CACHE_PURGE_TIMEOUT, 60);
    purgeTimeout = (purgeTimeout > 0) ? purgeTimeout : 0;
    if (purgeTimeout > 0) {
      scheduler.schedule(new FileSystemCachePurger(),
                         purgeInterval, purgeInterval, TimeUnit.SECONDS);
    }
  }
View Full Code Here

Examples of org.apache.log4j.component.scheduler.Scheduler

   * The scheduler is lazily instantiated.
   * @return this repository's own scheduler.
   */
  public Scheduler getScheduler() {
    if (scheduler == null) {
      scheduler = new Scheduler();
      scheduler.setDaemon(true);
      scheduler.start();
    }
    return scheduler;
  }
View Full Code Here

Examples of org.apache.log4j.scheduler.Scheduler

    if(this.repository == null) {
      throw new IllegalStateException(
      "DBAppender cannot function without a reference to its owning repository");
    }

    Scheduler scheduler = this.repository.getScheduler();
   
    scheduler.schedule(
        receiverJob, System.currentTimeMillis() + 500, refreshMillis);
  
  }
View Full Code Here

Examples of org.apache.ode.bpel.iapi.Scheduler

    final Callable executionCallable;
   
    if(isTwoWay)
    {
      // Defer the invoke until the transaction commits.
      Scheduler scheduler = executionEnvironment.getScheduler();
      executionCallable = new TwoWayCallable(mex.getMessageExchangeId());
      scheduler.registerSynchronizer(new Scheduler.Synchronizer() {

            public void afterCompletion(boolean success)
            {
              // If the TX is rolled back, then we don't send the request.
              if (!success) return;

              // The invocation must happen in a separate thread, holding on the afterCompletion
              // blocks other operations that could have been listed there as well.
              ExecutorService executorService = executionEnvironment.getExecutorService();
              executorService.submit(executionCallable);
            }
           
            public void beforeCompletion(){}
          }
      );

      mex.replyAsync();
    }
    else
    {
      // one-way invocation, also defer the invoke until the transaction commits.
      Scheduler scheduler = executionEnvironment.getScheduler();
      executionCallable = new OneWayCallable(mex.getMessageExchangeId());
     
      scheduler.registerSynchronizer(new Scheduler.Synchronizer() {
   
    public void beforeCompletion() {
     
    }
   
View Full Code Here

Examples of org.apache.openejb.quartz.Scheduler

            }
        }
    }

    private void resumePersistentSchedulers(final AppContext appContext) {
        final Scheduler globalScheduler = SystemInstance.get().getComponent(Scheduler.class);
        final Collection<Scheduler> schedulers = new ArrayList<Scheduler>();
        for (final BeanContext ejb : appContext.getBeanContexts()) {
            final Scheduler scheduler = ejb.get(Scheduler.class);
            if (scheduler == null || scheduler == globalScheduler || schedulers.contains(scheduler)) {
                continue;
            }

            schedulers.add(scheduler);
            try {
                scheduler.resumeAll();
            } catch (final Exception e) {
                logger.warning("Can't resume scheduler for " + ejb.getEjbName(), e);
            }
        }
    }
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.