org.quartz.SchedulerContext Java Examples

The following examples show how to use org.quartz.SchedulerContext. You can vote up the ones you like or vote down the ones you don't like, and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: SchedulerJob.java    From datacollector with Apache License 2.0 6 votes vote down vote up
@Override
public void execute(JobExecutionContext jobExecutionContext) {
  try {
    SchedulerContext schedulerContext = jobExecutionContext.getScheduler().getContext();
    PushSource.Context pushSourceContext = (PushSource.Context) schedulerContext.get(
        SchedulerPushSource.PUSH_SOURCE_CONTEXT
    );
    if (pushSourceContext != null) {
      BatchContext batchContext = pushSourceContext.startBatch();
      Record record = pushSourceContext.createRecord("cronRecord");
      LinkedHashMap<String, Field> linkedHashMap = new LinkedHashMap<>();
      linkedHashMap.put("timestamp", Field.createDatetime(new Date()));
      record.set(Field.createListMap(linkedHashMap));
      batchContext.getBatchMaker().addRecord(record);
      pushSourceContext.processBatch(batchContext);
    }
  } catch (SchedulerException ex) {
    LOG.error(ex.getMessage(), ex);
  }
}
 
Example #2
Source File: ChannelStaticJob.java    From Lottery with GNU General Public License v2.0 6 votes vote down vote up
protected void executeInternal(JobExecutionContext context)throws JobExecutionException {
try {  
        SchedulerContext schCtx = context.getScheduler().getContext();  
           //获取Spring中的上下文    
        ApplicationContext appCtx = (ApplicationContext)schCtx.get("applicationContext");  
        this.staticPageSvc= (StaticPageSvc)appCtx.getBean("staticPageSvc");  
        JobDataMap jdm=context.getJobDetail().getJobDataMap();
		//获取栏目
        String channelIdStr=(String) jdm.get(CmsTask.TASK_PARAM_CHANNEL_ID);
        if(!StringUtils.isBlank(channelIdStr)){
        	this.channelId=Integer.parseInt(channelIdStr);
        	if(channelId.equals(0)){
        		channelId=null;
        	}
        }
		//获取站点
        String siteIdStr=(String) jdm.get(CmsTask.TASK_PARAM_SITE_ID);
        if(!StringUtils.isBlank(siteIdStr)){
        	this.siteId=Integer.parseInt(siteIdStr);
        }
    } catch (SchedulerException e1) {  
        // TODO 尚未处理异常  
        e1.printStackTrace();  
    }   
    staitcChannel();
}
 
Example #3
Source File: IndexStaticJob.java    From Lottery with GNU General Public License v2.0 6 votes vote down vote up
protected void executeInternal(JobExecutionContext context)throws JobExecutionException {
   try {  
       SchedulerContext schCtx = context.getScheduler().getContext();  
       JobDataMap jdm=context.getJobDetail().getJobDataMap();
        //获取Spring中的上下文    
       ApplicationContext appCtx = (ApplicationContext)schCtx.get("applicationContext");  
       this.cmsSiteMng= (CmsSiteMng)appCtx.getBean("cmsSiteMng");  
       this.staticPageSvc= (StaticPageSvc)appCtx.getBean("staticPageSvc");  
       this.sessionFactory=(SessionFactory) appCtx.getBean("sessionFactory");
       this.siteId=Integer.parseInt((String) jdm.get(CmsTask.TASK_PARAM_SITE_ID));
   } catch (SchedulerException e1) {  
       // TODO 尚未处理异常  
       e1.printStackTrace();  
   }   
	staticIndex();
}
 
Example #4
Source File: RequestJob.java    From ingestion with Apache License 2.0 6 votes vote down vote up
/**
 * {@inheritDoc}
 *
 * @param context
 */
@Override
public void execute(JobExecutionContext context) throws JobExecutionException {
    this.context = context;
    SchedulerContext schedulerContext = null;
    try {
        log.debug("Executing quartz job");
        schedulerContext = context.getScheduler().getContext();
        initProperties(schedulerContext);

        WebResource.Builder resourceBuilder = getBuilder();
        ClientResponse response = getResponse(resourceBuilder);

        if (response != null) {
            String responseAsString = response.getEntity(String.class);
            final List<Event> events = restSourceHandler
                    .getEvents(responseAsString, responseToHeaders(response.getHeaders()));
            queue.addAll(events);
            urlHandler.updateFilterParameters(getLastEvent(events));
        }

    } catch (Exception e) {
        log.error("Error getting Response: " + e.getMessage());
    }
}
 
Example #5
Source File: AppDailyJob.java    From cachecloud with Apache License 2.0 5 votes vote down vote up
@Override
public void action(JobExecutionContext context) {
    try {
        SchedulerContext schedulerContext = context.getScheduler().getContext();
        ApplicationContext applicationContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT_KEY);
        AppDailyDataCenter appDailyDataCenter = applicationContext.getBean("appDailyDataCenter", AppDailyDataCenter.class);
        appDailyDataCenter.sendAppDailyEmail();
    } catch (SchedulerException e) {
        logger.error(e.getMessage(), e);
    }
    
}
 
Example #6
Source File: AbstractJobTest.java    From cia with Apache License 2.0 5 votes vote down vote up
/**
 * Prepare context mock.
 *
 * @param jobContextMock the job context mock
 * @return the application context
 * @throws SchedulerException the scheduler exception
 */
protected  ApplicationContext prepareContextMock(final JobExecutionContext jobContextMock) throws SchedulerException {
	final Scheduler scheduler = Mockito.mock(Scheduler.class);		
	Mockito.when(jobContextMock.getScheduler()).thenReturn(scheduler);
	final SchedulerContext schedulerContext = Mockito.mock(SchedulerContext.class);
	Mockito.when(scheduler.getContext()).thenReturn(schedulerContext);		
	final ApplicationContext applicationContext = Mockito.mock(ApplicationContext.class);		
	Mockito.when(schedulerContext.get(Mockito.any(String.class))).thenReturn(applicationContext);
	return applicationContext;
}
 
Example #7
Source File: AbstractJob.java    From cia with Apache License 2.0 5 votes vote down vote up
/**
 * Gets the job context holder.
 *
 * @param jobContext
 *            the job context
 * @return the job context holder
 */
protected final JobContextHolder getJobContextHolder(final JobExecutionContext jobContext) {
	final Scheduler scheduler = jobContext.getScheduler();
	    JobContextHolder bean = null;
	    try {
	    	final SchedulerContext schedulerContext = scheduler.getContext();
	        final ApplicationContext appContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT);
	        bean = appContext.getBean(JobContextHolder.class);
	    } catch (final SchedulerException e) {
	       LOGGER.error("Failed to get JobContextHolder",e );
	    }

	return bean;
}
 
Example #8
Source File: SchedulerServiceJob.java    From jolie with GNU Lesser General Public License v2.1 5 votes vote down vote up
@Override
public void execute( JobExecutionContext context ) throws JobExecutionException {
	try {
		SchedulerContext schedulerContext = context.getScheduler().getContext();
		SchedulerService service = (SchedulerService) schedulerContext.get( "schedulerService" );
		Value toSend = Value.create();
		toSend.getFirstChild( "jobName" ).setValue( context.getJobDetail().getKey().getName() );
		toSend.getFirstChild( "groupName" ).setValue( context.getJobDetail().getKey().getGroup() );
		service.sendMessage( CommMessage.createRequest( service.getOperationName(), "/", toSend ) );
	} catch( SchedulerException ex ) {
		Interpreter.getInstance().logSevere( ex );
	}
}
 
Example #9
Source File: JobDataMapManager.java    From niubi-job with Apache License 2.0 5 votes vote down vote up
/**
 * 初始化自动的调度器数据
 *
 * @param scheduler 调度器
 * @param jobBeanFactory JobBean工厂
 */
static void initAutomaticScheduler(Scheduler scheduler, JobBeanFactory jobBeanFactory) {
    try {
        SchedulerContext schedulerContext = scheduler.getContext();
        schedulerContext.put(JOB_BEAN_FACTORY_KEY, jobBeanFactory);
        schedulerContext.put(SCHEDULE_MODE_KEY, ScheduleMode.AUTOMATIC);
    } catch (SchedulerException e) {
        LoggerHelper.error("get schedule context failed.", e);
        throw new NiubiException(e);
    }
}
 
Example #10
Source File: JobDataMapManager.java    From niubi-job with Apache License 2.0 5 votes vote down vote up
/**
 * 初始化手动的调度器数据
 *
 * @param scheduler 调度器
 */
static void initManualScheduler(Scheduler scheduler) {
    try {
        SchedulerContext schedulerContext = scheduler.getContext();
        schedulerContext.put(SCHEDULE_MODE_KEY, ScheduleMode.MANUAL);
    } catch (SchedulerException e) {
        LoggerHelper.error("get schedule context failed.", e);
        throw new NiubiException(e);
    }
}
 
Example #11
Source File: SchedulerTest.java    From nexus-public with Eclipse Public License 1.0 5 votes vote down vote up
@Override
public void execute(JobExecutionContext context) throws JobExecutionException {
  try {
    SchedulerContext schedulerContext = context.getScheduler().getContext();
    schedulerContext.put(JOB_THREAD, Thread.currentThread());
    CyclicBarrier barrier = (CyclicBarrier) schedulerContext.get(BARRIER);
    barrier.await(TEST_TIMEOUT_SECONDS, TimeUnit.SECONDS);
  }
  catch (Throwable e) {
    e.printStackTrace();
    throw new AssertionError("Await on barrier was interrupted: " + e.toString());
  }
}
 
Example #12
Source File: ScheduleService.java    From elasticsearch-quartz with Apache License 2.0 5 votes vote down vote up
public SchedulerContext getContext() {
    try {
        return scheduler.getContext();
    } catch (final SchedulerException e) {
        throw new QuartzSchedulerException(e);
    }
}
 
Example #13
Source File: QuartzSupportTests.java    From spring4-understanding with Apache License 2.0 5 votes vote down vote up
@Test
public void schedulerFactoryBeanWithApplicationContext() throws Exception {
	TestBean tb = new TestBean("tb", 99);
	StaticApplicationContext ac = new StaticApplicationContext();

	final Scheduler scheduler = mock(Scheduler.class);
	SchedulerContext schedulerContext = new SchedulerContext();
	given(scheduler.getContext()).willReturn(schedulerContext);

	SchedulerFactoryBean schedulerFactoryBean = new SchedulerFactoryBean() {
		@Override
		protected Scheduler createScheduler(SchedulerFactory schedulerFactory, String schedulerName) {
			return scheduler;
		}
	};
	schedulerFactoryBean.setJobFactory(null);
	Map<String, Object> schedulerContextMap = new HashMap<String, Object>();
	schedulerContextMap.put("testBean", tb);
	schedulerFactoryBean.setSchedulerContextAsMap(schedulerContextMap);
	schedulerFactoryBean.setApplicationContext(ac);
	schedulerFactoryBean.setApplicationContextSchedulerContextKey("appCtx");
	try {
		schedulerFactoryBean.afterPropertiesSet();
		schedulerFactoryBean.start();
		Scheduler returnedScheduler = schedulerFactoryBean.getObject();
		assertEquals(tb, returnedScheduler.getContext().get("testBean"));
		assertEquals(ac, returnedScheduler.getContext().get("appCtx"));
	}
	finally {
		schedulerFactoryBean.destroy();
	}

	verify(scheduler).start();
	verify(scheduler).shutdown(false);
}
 
Example #14
Source File: InspectorJob.java    From cachecloud with Apache License 2.0 5 votes vote down vote up
@Override
public void action(JobExecutionContext context) {
    try {
        long start = System.currentTimeMillis();
        SchedulerContext schedulerContext = context.getScheduler().getContext();
        ApplicationContext applicationContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT_KEY);
        // 应用相关
        InspectHandler inspectHandler;
        JobDataMap jobDataMap = context.getMergedJobDataMap();
        String inspectorType = MapUtils.getString(jobDataMap, "inspectorType");
        if (StringUtils.isBlank(inspectorType)) {
            logger.error("=====================InspectorJob:inspectorType is null=====================");
            return;
        } else if (inspectorType.equals("host")) {
            inspectHandler = applicationContext.getBean("hostInspectHandler", InspectHandler.class);
        } else if (inspectorType.equals("app")) {
            inspectHandler = applicationContext.getBean("appInspectHandler", InspectHandler.class);
        } else {
            logger.error("=====================InspectorJob:inspectorType not match:{}=====================", inspectorType);
            return;
        }
        inspectHandler.handle();
        long end = System.currentTimeMillis();
        logger.info("=====================InspectorJob {} Done! cost={} ms=====================",
                inspectHandler.getClass().getSimpleName(), (end - start));
    } catch (Exception e) {
        logger.error(e.getMessage(), e);
        throw new RuntimeException(e);
    }
}
 
Example #15
Source File: SystemConfigRefreshJob.java    From cachecloud with Apache License 2.0 5 votes vote down vote up
@Override
public void action(JobExecutionContext context) {
    try {
        SchedulerContext schedulerContext = context.getScheduler().getContext();
        ApplicationContext applicationContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT_KEY);
        ConfigService configService = applicationContext.getBean("configService", ConfigService.class);
        configService.reloadSystemConfig();
    } catch (SchedulerException e) {
        logger.error(e.getMessage(), e);
    }
    
}
 
Example #16
Source File: MachineMonitorJob.java    From cachecloud with Apache License 2.0 5 votes vote down vote up
@Override
public void action(JobExecutionContext context) {
    try {
        JobDataMap dataMap = context.getMergedJobDataMap();
        String ip = dataMap.getString(ConstUtils.HOST_KEY);
        long hostId = dataMap.getLong(ConstUtils.HOST_ID_KEY);

        SchedulerContext schedulerContext = context.getScheduler().getContext();
        ApplicationContext applicationContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT_KEY);
        MachineCenter machineCenter = applicationContext.getBean("machineCenter", MachineCenter.class);
        machineCenter.asyncMonitorMachineStats(hostId, ip);
    } catch (SchedulerException e) {
        logger.error(e.getMessage(), e);
    }
}
 
Example #17
Source File: ErrorStatisticsJob.java    From cachecloud with Apache License 2.0 5 votes vote down vote up
@Override
    public void action(JobExecutionContext context) {
        Date date = new Date();
        SimpleDateFormat dateFormat = new SimpleDateFormat("yyyy-MM-dd");
        SchedulerContext schedulerContext;
        try {
            schedulerContext = context.getScheduler().getContext();
            ApplicationContext applicationContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT_KEY);
            EmailComponent emailComponent = applicationContext.getBean("emailComponent", EmailComponent.class);
            ErrorLoggerWatcherMBean errorLoggerWatcher = applicationContext.getBean("errorLoggerWatcher", ErrorLoggerWatcherMBean.class);
//            if (errorLoggerWatcher.getTotalErrorCount() == 0L) {
//                logger.warn("errorLoggerWatcher.totalErrorCount == 0 -o-");
//                return;
//            }
            String title = "CacheCloud异常统计, 日期:" + dateFormat.format(date) + ";服务器:" + System.getProperty("local.ip") + ";总数:" + errorLoggerWatcher.getTotalErrorCount();

            StringBuilder buffer = new StringBuilder();
            buffer.append(title + ":<br/>");
            for (Map.Entry<String, Long> entry : errorLoggerWatcher.getErrorInfos().entrySet()) {
                Long num = entry.getValue();
                if (num == 0L) {
                    continue;
                }
                String key = entry.getKey();
                buffer.append(key + "=" + num + "<br/>");
            }

            emailComponent.sendMailToAdmin(title, buffer.toString());
            //清理异常
            errorLoggerWatcher.clear();
        } catch (SchedulerException e) {
            logger.error(e.getMessage(), e);
        }
        
    }
 
Example #18
Source File: InstanceAlertValueJob.java    From cachecloud with Apache License 2.0 5 votes vote down vote up
@Override
public void action(JobExecutionContext context) {
    try {
        long startTime = System.currentTimeMillis();
        SchedulerContext schedulerContext = context.getScheduler().getContext();
        ApplicationContext applicationContext = (ApplicationContext) schedulerContext.get(APPLICATION_CONTEXT_KEY);
        InstanceAlertConfigService instanceAlertConfigService = applicationContext.getBean("instanceAlertConfigService", InstanceAlertConfigService.class);
        instanceAlertConfigService.monitorLastMinuteAllInstanceInfo();
        logger.info("InstanceAlertValueJob cost time {} ms", (System.currentTimeMillis() - startTime));
    } catch (SchedulerException e) {
        logger.error(e.getMessage(), e);
    }
    
}
 
Example #19
Source File: RemoteScheduler.java    From AsuraFramework with Apache License 2.0 5 votes vote down vote up
/**
 * <p>
 * Returns the <code>SchedulerContext</code> of the <code>Scheduler</code>.
 * </p>
 */
public SchedulerContext getContext() throws SchedulerException {
    try {
        return getRemoteScheduler().getSchedulerContext();
    } catch (RemoteException re) {
        throw invalidateHandleCreateException(
                "Error communicating with remote scheduler.", re);
    }
}
 
Example #20
Source File: RemoteScheduler.java    From lams with GNU General Public License v2.0 5 votes vote down vote up
/**
 * <p>
 * Returns the <code>SchedulerContext</code> of the <code>Scheduler</code>.
 * </p>
 */
public SchedulerContext getContext() throws SchedulerException {
    try {
        return getRemoteScheduler().getSchedulerContext();
    } catch (RemoteException re) {
        throw invalidateHandleCreateException(
                "Error communicating with remote scheduler.", re);
    }
}
 
Example #21
Source File: CommandExecutionJobTest.java    From roboconf-platform with Apache License 2.0 5 votes vote down vote up
@Before
public void prepare() throws Exception {

	JobDataMap map = new JobDataMap( new HashMap<String,String> ());
	map.put( RoboconfScheduler.APP_NAME, "app" );
	map.put( RoboconfScheduler.JOB_NAME, "job" );
	map.put( RoboconfScheduler.CMD_NAME, "cmd" );

	JobDetail jobDetail = Mockito.mock( JobDetail.class );
	Mockito.when( jobDetail.getJobDataMap()).thenReturn( map );

	this.manager = Mockito.spy( new Manager());
	this.manager.configurationMngr().setWorkingDirectory( this.folder.newFolder());

	this.commandMngr = Mockito.mock( ICommandsMngr.class );
	Mockito.when( this.manager.commandsMngr()).thenReturn( this.commandMngr );

	this.context = Mockito.mock( JobExecutionContext.class );
	Mockito.when( this.context.get( RoboconfScheduler.MANAGER )).thenReturn( this.manager );
	Mockito.when( this.context.getJobDetail()).thenReturn( jobDetail );

	Scheduler scheduler = Mockito.mock( Scheduler.class );
	Mockito.when( this.context.getScheduler()).thenReturn( scheduler );

	SchedulerContext schedulerCtx = Mockito.mock( SchedulerContext.class );
	Mockito.when( scheduler.getContext()).thenReturn( schedulerCtx );
	Mockito.when( schedulerCtx.get( RoboconfScheduler.MANAGER )).thenReturn( this.manager );
}
 
Example #22
Source File: RequestJob.java    From ingestion with Apache License 2.0 5 votes vote down vote up
/**
 * Initialize properties that are received in the {@code SchedulerContext}.
 *
 * @param context
 */
@SuppressWarnings("unchecked")
public void initProperties(SchedulerContext context) {
    queue = (LinkedBlockingQueue<Event>) context.get("queue");
    properties = (Map<String, String>) context.get("properties");
    client = (Client) context.get("client");
    restSourceHandler = (RestSourceHandler) context.get(HANDLER);
    urlHandler = (UrlHandler) context.get(URL_HANDLER);

}
 
Example #23
Source File: ContentStaticJob.java    From Lottery with GNU General Public License v2.0 5 votes vote down vote up
protected void executeInternal(JobExecutionContext context)
		throws JobExecutionException {
			try {
				SchedulerContext schCtx = context.getScheduler().getContext();
				// 获取Spring中的上下文
				ApplicationContext appCtx = (ApplicationContext) schCtx.get("applicationContext");
				this.staticPageSvc = (StaticPageSvc) appCtx.getBean("staticPageSvc");
				JobDataMap jdm=context.getJobDetail().getJobDataMap();
				//获取栏目
		        String channelIdStr=(String) jdm.get(CmsTask.TASK_PARAM_CHANNEL_ID);
		        if(!StringUtils.isBlank(channelIdStr)){
		        	this.channelId=Integer.parseInt(channelIdStr);
		        	if(channelId.equals(0)){
		        		channelId=null;
		        	}
		        }
				//获取站点
		        String siteIdStr=(String) jdm.get(CmsTask.TASK_PARAM_SITE_ID);
		        if(!StringUtils.isBlank(siteIdStr)){
		        	this.siteId=Integer.parseInt(siteIdStr);
		        }
			} catch (SchedulerException e1) {
				// TODO 尚未处理异常
				e1.printStackTrace();
			}
			staticContent();
}
 
Example #24
Source File: MonitoringJob.java    From lams with GNU General Public License v2.0 5 votes vote down vote up
protected Object getService(JobExecutionContext context, String serviceName) throws JobExecutionException {
try {
    SchedulerContext sc = context.getScheduler().getContext();
    ApplicationContext cxt = (ApplicationContext) sc.get(MonitoringJob.CONTEXT_NAME);
    return cxt.getBean(serviceName);
} catch (SchedulerException e) {
    throw new JobExecutionException("Failed look up the " + serviceName + " " + e.toString());
}
   }
 
Example #25
Source File: QuartzSupportTests.java    From java-technology-stack with MIT License 5 votes vote down vote up
@Test
public void schedulerFactoryBeanWithApplicationContext() throws Exception {
	TestBean tb = new TestBean("tb", 99);
	StaticApplicationContext ac = new StaticApplicationContext();

	final Scheduler scheduler = mock(Scheduler.class);
	SchedulerContext schedulerContext = new SchedulerContext();
	given(scheduler.getContext()).willReturn(schedulerContext);

	SchedulerFactoryBean schedulerFactoryBean = new SchedulerFactoryBean() {
		@Override
		protected Scheduler createScheduler(SchedulerFactory schedulerFactory, String schedulerName) {
			return scheduler;
		}
	};
	schedulerFactoryBean.setJobFactory(null);
	Map<String, Object> schedulerContextMap = new HashMap<>();
	schedulerContextMap.put("testBean", tb);
	schedulerFactoryBean.setSchedulerContextAsMap(schedulerContextMap);
	schedulerFactoryBean.setApplicationContext(ac);
	schedulerFactoryBean.setApplicationContextSchedulerContextKey("appCtx");
	try {
		schedulerFactoryBean.afterPropertiesSet();
		schedulerFactoryBean.start();
		Scheduler returnedScheduler = schedulerFactoryBean.getObject();
		assertEquals(tb, returnedScheduler.getContext().get("testBean"));
		assertEquals(ac, returnedScheduler.getContext().get("appCtx"));
	}
	finally {
		schedulerFactoryBean.destroy();
	}

	verify(scheduler).start();
	verify(scheduler).shutdown(false);
}
 
Example #26
Source File: AcquisiteJob.java    From Lottery with GNU General Public License v2.0 5 votes vote down vote up
protected void executeInternal(JobExecutionContext context)throws JobExecutionException {
try {
	SchedulerContext schCtx = context.getScheduler().getContext();
	JobDataMap jdm=context.getJobDetail().getJobDataMap();
	//获取采集源
	this.acquId=Integer.parseInt((String) jdm.get(CmsTask.TASK_PARAM_ACQU_ID));
	// 获取Spring中的上下文
	ApplicationContext appCtx = (ApplicationContext) schCtx.get("applicationContext");
	this.acquisitionSvc = (AcquisitionSvc) appCtx.getBean("acquisitionSvc");
} catch (SchedulerException e1) {
	// TODO 尚未处理异常
	e1.printStackTrace();
}
	acquStart();
}
 
Example #27
Source File: QuartzSupportTests.java    From spring-analysis-note with MIT License 5 votes vote down vote up
@Test
public void schedulerFactoryBeanWithApplicationContext() throws Exception {
	TestBean tb = new TestBean("tb", 99);
	StaticApplicationContext ac = new StaticApplicationContext();

	final Scheduler scheduler = mock(Scheduler.class);
	SchedulerContext schedulerContext = new SchedulerContext();
	given(scheduler.getContext()).willReturn(schedulerContext);

	SchedulerFactoryBean schedulerFactoryBean = new SchedulerFactoryBean() {
		@Override
		protected Scheduler createScheduler(SchedulerFactory schedulerFactory, String schedulerName) {
			return scheduler;
		}
	};
	schedulerFactoryBean.setJobFactory(null);
	Map<String, Object> schedulerContextMap = new HashMap<>();
	schedulerContextMap.put("testBean", tb);
	schedulerFactoryBean.setSchedulerContextAsMap(schedulerContextMap);
	schedulerFactoryBean.setApplicationContext(ac);
	schedulerFactoryBean.setApplicationContextSchedulerContextKey("appCtx");
	try {
		schedulerFactoryBean.afterPropertiesSet();
		schedulerFactoryBean.start();
		Scheduler returnedScheduler = schedulerFactoryBean.getObject();
		assertEquals(tb, returnedScheduler.getContext().get("testBean"));
		assertEquals(ac, returnedScheduler.getContext().get("appCtx"));
	}
	finally {
		schedulerFactoryBean.destroy();
	}

	verify(scheduler).start();
	verify(scheduler).shutdown(false);
}
 
Example #28
Source File: FoxbpmScheduler.java    From FoxBPM with Apache License 2.0 4 votes vote down vote up
public SchedulerContext getContext() throws SchedulerException {
	return scheduler.getContext();
}
 
Example #29
Source File: AutowiringSpringBeanJobFactory.java    From syncope with Apache License 2.0 4 votes vote down vote up
@Override
public void setSchedulerContext(final SchedulerContext schedulerContext) {
    super.setSchedulerContext(schedulerContext);
    this.schedulerContext = schedulerContext;
}
 
Example #30
Source File: AbstractScheduler.java    From smarthome with Eclipse Public License 2.0 4 votes vote down vote up
@Override
public SchedulerContext getContext() throws SchedulerException {
    throw new UnsupportedOperationException();
}