Network Security Internet Technology Development Database Servers Mobile Phone Android Software Apple Software Computer Software News IT Information

In addition to Weibo, there is also WeChat

Please pay attention

WeChat public account

Shulou

Spring Boot integrated quartz how to implement timing tasks and support switching task data sources

2025-04-06 Update From: SLTechnology News&Howtos shulou NAV: SLTechnology News&Howtos > Internet Technology >

Share

Shulou(Shulou.com)06/02 Report--

This article introduces the relevant knowledge of "Spring Boot integrated quartz how to implement timed tasks and support switching task data sources". In the operation of actual cases, many people will encounter such a dilemma, so let the editor lead you to learn how to deal with these situations. I hope you can read it carefully and be able to achieve something!

Org.quartz implements timing tasks and customizes switching task data sources.

Timed tasks are often used to deal with all kinds of periodic tasks at work. Org.quartz is an excellent framework for dealing with such scheduled tasks. As the project progresses little by little, we are not satisfied with the task just being executed regularly, we also want to have more control over the task and can intervene artificially at any time, so we need to have a more in-depth understanding of quartz. With the popularity of micro-services, the situation of multiple data sources in projects is becoming more and more common, and the function of integrating multi-data sources switching in scheduled tasks also needs to be integrated.

Integrating quartz to realize timing tasks

Integrating quartz to realize timing tasks

The basic concept Job which needs to be understood to realize the timing task in quartz

By implementing the Job class, we write down what we want the timed task to do in the implementation method, and then give it to quartz to manage.

JobDetail

Job is only responsible for implementing specific tasks, so you also need to use JobDetail to store some basic information that describes Job.

Quartz JobBuilder

The builder-style API provided for constructing JobDetail entities. You can use it to build a JobDetail like this:

@ Beanpublic JobDetail jobDetail () {return JobBuilder.newJob () .ofType (SampleJob.class) .storeDurantee () .withIdentity ("Qrtz_Job_Detail") .withDescription ("Invoke SampleJob service...") .build ();} Spring JobDetailFactoryBean

How to configure JobDetail in Spring:

@ Beanpublic JobDetailFactoryBean jobDetail () {JobDetailFactoryBean jobDetailFactory = new JobDetailFactoryBean (); jobDetailFactory.setJobClass (SampleJob.class); jobDetailFactory.setDescription ("Invoke SampleJob service..."); jobDetailFactory.setDurability (true); return jobDetailFactory;} Trigger

Trigger, which represents the configuration of a scheduling parameter, when to schedule:

@ Beanpublic Trigger trigger (JobDetail job) {return TriggerBuilder.newTrigger () .forJob (job) .withIdentity ("Qrtz_Trigger") .withDescription ("Sample trigger") .withschedule (simpleSchedule () .repeatForever () .withIntervalInHours (1)) .build ();} Scheduler

A scheduler, which registers a scheduler through Job and Trigger:

@ Beanpublic Scheduler scheduler (Trigger trigger, JobDetail job) {StdSchedulerFactory factory = new StdSchedulerFactory (); factory.initialize (new ClassPathResource ("quartz.properties"). GetInputStream (); Scheduler scheduler = factory.getScheduler (); scheduler.setJobFactory (springBeanJobFactory ()); scheduler.scheduleJob (job, trigger); scheduler.start (); return scheduler;} add a Job to the system

In quartz, Job is the task that we need to execute, and the Scheduler scheduler is responsible for scheduling tasks. We rely on the established Trigger to execute tasks regularly.

So first of all, we need to combine the above foundation to add a Job to the system.

AddJob public void addJob (BaseJob job) throws SchedulerException {/ * * create a JobDetail instance, bind the Job implementation class * JobDetail to indicate a specific executable scheduler, and job is the content to be executed by this executable scheduler * in addition, JobDetail also contains the scheme and policy for this task scheduling * * / / indicates the name of the job and the name of the group And bind the job class JobDetail jobDetail = JobBuilder.newJob (job.getBeanClass ()) .withidentity (job.getJobKey ()) .withDescription (job.getDescription ()) .usingJobData (job.getDataMap ()) .build () / * Trigger represents the configuration of a scheduling parameter. When to schedule * / define the scheduling trigger rule, use the cronTrigger rule Trigger trigger = TriggerBuilder.newTrigger () .withidentity (job.getJobName ()) Job.getJobGroup () .withschedule (CronScheduleBuilder.cronSchedule (job.getCron_Expression () .startNow () .build () / register tasks and triggers to scheduler.scheduleJob (jobDetail,trigger); / / determine whether the scheduler starts if (! scheduler.isStarted ()) {scheduler.start ();} log.info (String.format ("scheduled tasks:% s% s-added to the scheduler!", job.getJobGroup (), job.getJobName ();}

First we need to define our Job, then initialize JobDetail and Trigger through Job, and finally register JobDetail and Trigger with the scheduler.

BaseJob

The structure of Job is as follows:

Public abstract class BaseJob implements Job,Serializable {private static final long serialVersionUID = 1L; private static final String JOB_MAP_KEY = "self"; / * * Task name * / private String jobName; / * * Task grouping * / private String jobGroup; / * whether the task status starts the task * / private String jobStatus / * cron expression * / private String cronExpression; / * describes * / private String description; / * the method package name of which class to call when the task executes + class name * / private Class beanClass = this.getClass (); / * whether the task has a state * / private String isConcurrent / * Spring bean * / private String springBean; / * method name called by the task * / private String methodName; / * the data source used by the task * / private String dataSource = DataSourceEnum.DB1.getName () / * in order to persist the executed task to the database * / @ JsonIgnore private JobDataMap dataMap = new JobDataMap (); public JobKey getJobKey () {return JobKey.jobKey (jobName, jobGroup); / / Task name and group constitute task key}.}

You can see some basic information about tasks defined in Job, focusing on the dataSource and dataMap attributes. Where dataSource is the data source used by the task and is given a default value; because the task is persisted to the database after it is added, the parsing task uses dataMap later.

SchedulerConfig

When adding Job, both JobDetail and Trigger are generated by the keyword new, while the scheduler Scheduler needs to be maintained in a container.

@ Configuration@Orderpublic class SchedulerConfig {@ Autowired private MyJobFactory myJobFactory; @ Value ("${spring.profiles.active}") private String profile; / * * obtain the instance of Scheduler through SchedulerFactoryBean * / @ Bean (name = "scheduler") public Scheduler scheduler () throws Exception {return schedulerFactoryBean () .getScheduler ();} @ Bean public SchedulerFactoryBean schedulerFactoryBean () throws IOException {SchedulerFactoryBean factory = new SchedulerFactoryBean () Factory.setOverwriteExistingJobs (true); / / delayed startup factory.setStartupDelay (20); / / load quartz data source configuration factory.setQuartzProperties (quartzProperties ()); / / Custom JobFactory for Spring injection factory.setJobFactory (myJobFactory) / * Global listener configuration * / JobListener myJobListener = new SchedulerListener (); factory.setGlobalJobListeners (myJobListener); / / directly add as global listener return factory;} @ Bean public Properties quartzProperties () throws IOException {PropertiesFactoryBean propertiesFactoryBean = new PropertiesFactoryBean () If (Util.PRODUCT.equals (profile)) {/ / formal environment System.out.println ("formal environment quartz configuration"); propertiesFactoryBean.setLocation (new ClassPathResource ("/ quartz-prod.properties"));} else {System.out.println ("test environment quartz configuration"); propertiesFactoryBean.setLocation (new ClassPathResource ("/ quartz.properties")) } / / initialize the object propertiesFactoryBean.afterPropertiesSet () after the attributes in quartz.properties are read and injected; return propertiesFactoryBean.getObject ();} / * * quartz initialization listener * / @ Bean public QuartzInitializerListener executorListener () {return new QuartzInitializerListener ();}}

In the above code, add scheduler to the Spring container. Scheduler is maintained by SchedulerFactoryBean, makes some basic settings for the scheduler factory in SchedulerFactoryBean and loads the quartz data source configuration from the configuration file (the reading of the configuration file is automatically switched according to the running environment profile), and a global listener is configured to listen to the execution of the task.

MyJobFactory

Use the JobFactory provided by Spring.

@ Componentpublic class MyJobFactory extends AdaptableJobFactory {@ Autowired private AutowireCapableBeanFactory capableBeanFactory; @ Override protected Object createJobInstance (TriggerFiredBundle bundle) throws Exception {/ / call the parent class's method Object jobInstance = super.createJobInstance (bundle); / / inject capableBeanFactory.autowireBean (jobInstance); return jobInstance;}} quartz.properties

Quartz.properties contains some configuration information for the quartz connection database.

#\ u56FA\ u5B9A\ u524D\ u7F00org.quartz#\ u4E3B\ u8981\ u5206\ u4E3Ascheduler\ u3001threadPool\ u3001jobStore\ u3001plugin\ u7B49\ u90E8\ u5206##org.quartz.scheduler.instanceName = DefaultQuartzSchedulerorg.quartz.scheduler.rmi.export = falseorg.quartz.scheduler.rmi.proxy = falseorg.quartz.scheduler.wrapJobExecutionInUserTransaction = false#\ u5B9E\ u4F8B\ u5316ThreadPool\ u65F6\ uFF0C\ u4F7F\ u7528\ u7684\ u7EBF\ u7A0B\ u7C7B\ u4E3ASimpleThreadPoolorg.quartz.threadPool.class = org.quartz.simpl.SimpleThreadPool# threadCount\ u548CthreadPriority\ u5C06\ U4EE5setter\ u7684\ u5F62\ u5F0F\ u6CE8\ u5165ThreadPool\ u5B9E\ u4F8B#\ u5E76\ u53D1\ u4E2A\ u6570org.quartz.threadPool.threadCount = "\ u4F18\ u5148\ u7EA7org.quartz.threadPool.threadPriority = 5org.quartz.threadPool.threadsInheritContextClassLoaderOfInitializingThread = trueorg.quartz.jobStore.misfireThreshold = 500 cycles\ u9ED8\ u8BA4\ u5B58\ u50A8\ u5728\ u5185\ u5B58\ u4E2D#org.quartz.jobStore.class = org.quartz.simpl.RAMJobStore#\ u6301\ u4E45\ u5316org.quartz.jobStore.class = org.quartz.impl.jdbcjobstore .JobStoreTX # org.quartz.jobStore.useProperties=falseorg.quartz.jobStore.tablePrefix = QRTZ_org.quartz.jobStore.dataSource = qzDSorg.quartz.dataSource.qzDS.driver = com.mysql.jdbc.Driverorg.quartz.dataSource.qzDS.URL=jdbc:mysql://127.0.0.1:3306/quartz?characterEncoding=UTF-8&useSSL=false&testOnBorrow=true&testWhileIdle=trueorg.quartz.dataSource.qzDS.user=quartzorg.quartz.dataSource.qzDS.password=123456org.quartz.dataSource.qzDS.maxConnections = 30org.quartz.dataSource.qzDS.validationQuery = SELECT 1 FROM DUALorg.quartz. DataSource.qzDS.validateOnCheckout = trueorg.quartz.dataSource.qzDS.idleConnectionValidationSeconds = 40#org.quartz.dataSource.qzDS.discardIdleConnectionsSeconds = 60

Quartz will persist Job to the database according to this configuration file, so quartz will need to initialize some database tables, and the table structure file is at the end of the article.

SchedulerListener

The scheduler listener is used to listen to the execution status of the task.

Public class SchedulerListener implements JobListener {private final Logger LOG = LoggerFactory.getLogger (SchedulerListener.class); public static final String LISTENER_NAME = "QuartSchedulerListener"; @ Override public String getName () {return LISTENER_NAME; / / must return a name} / / before the task is scheduled @ Override public void jobToBeExecuted (JobExecutionContext context) {String dataSource = context.getJobDetail () .getJobDataMap () .getString ("dataSource") / / switch the data source of the task DataSourceContextHolder.setDB (dataSource); String jobName = context.getJobDetail (). GetKey (). ToString (); LOG.info ("Job {} is going to start,switch dataSource to {}, Thread name {}", jobName, dataSource, Thread.currentThread (). GetName ()) } / / Task scheduling rejected @ Override public void jobExecutionVetoed (JobExecutionContext context) {String jobName = context.getJobDetail () .getKey () .toString (); LOG.error ("job {} is jobExecutionVetoed", jobName) / / can do some logging reasons} / / after the task is scheduled @ Override public void jobWasExecuted (JobExecutionContext context, JobExecutionException jobException) {/ / clear the stored data source String jobName = context.getJobDetail (). GetKey (). ToString (); DataSourceContextHolder.clearDB (); LOG.info ("Job: {} is finished", jobName) If (jobException! = null & &! jobException.getMessage (). Equals (")) {LOG.error (" Exception thrown by: "+ jobName +" Exception: "+ jobException.getMessage ());}

SchedulerListener listens for the status of tasks before scheduling, after scheduling and when scheduling is rejected, and processes the data sources used by the task before and after the task is scheduled. If there is no need for data source switching in the project, this listener is not needed, and the quartz integration has been completed.

Multiple data source handoff

Multiple data source handoff

Overwrite the existing data sources in Spring Boot by customizing DynamicDataSource.

DataSourceConfig

Initialize the data sources that may be used in the project for switching by reading different data sources in the configuration file.

/ * multiple data source configuration class * / @ Configurationpublic class DataSourceConfig {/ / data source 1 @ Bean (name = "datasource1") @ ConfigurationProperties (prefix = "spring.datasource.db1") / / prefix public DataSource dataSource1 () {return DataSourceBuilder.create () .build () of the corresponding attribute in / / application.properteis } / / data source 2 @ Bean (name = "datasource2") @ ConfigurationProperties (prefix = "spring.datasource.db2") / / the prefix public DataSource dataSource2 () {return DataSourceBuilder.create () .build () of the corresponding attribute in application.properteis } / * dynamic data sources: dynamically switch between different data sources through AOP * * @ return * / @ Primary @ Bean (name = "dynamicDataSource") public DataSource dynamicDataSource () {DynamicDataSource dynamicDataSource = new DynamicDataSource (); / / default data source dynamicDataSource.setDefaultTargetDataSource (dataSource1 ()) / / configure multiple data sources Map dsMap = new HashMap (); dsMap.put (DataSourceEnum.DB1.getName (), dataSource1 ()); dsMap.put (DataSourceEnum.DB2.getName (), dataSource2 ()); dynamicDataSource.setTargetDataSources (dsMap); return dynamicDataSource;} @ Bean public SqlSessionFactory sqlSessionFactory (DataSource dataSource) throws Exception {SqlSessionFactoryBean sqlSessionFactoryBean = new SqlSessionFactoryBean () / / set data source sqlSessionFactoryBean.setDataSource (dataSource); return sqlSessionFactoryBean.getObject ();} / * configure @ Transactional annotated things * * @ return * / @ Bean public PlatformTransactionManager transactionManager () {return new DataSourceTransactionManager (dynamicDataSource ()) }} data source configuration spring: datasource: db1: driver-class-name: com.mysql.cj.jdbc.Driver username: doctor password: 123456 type: com.zaxxer.hikari.HikariDataSource jdbc-url: jdbc:mysql://127.0.0.1:3306/doctor?useSSL=false&testOnBorrow=true&testWhileIdle=true db2: driver-class-name: com.mysql.cj.jdbc.Driver username: quartz password: 123456 type : com.zaxxer.hikari.HikariDataSource jdbc-url: jdbc:mysql://127.0.0.1:3307/quartz?useSSL=false&testOnBorrow=true&testWhileIdle=trueDataSourceContextHolder

Because quartz executes Job through different threads during execution, the data source situation used by threads is saved through ThreadLocal here.

/ * Save local data source * / public class DataSourceContextHolder {private static final Logger LOG = LoggerFactory.getLogger (DataSourceContextHolder.class); / * * default data source * / public static final String DEFAULT_DS = DataSourceEnum.DB1.getName (); / * * ThreadLocal will be explained later * / private static final ThreadLocal contextHolder = new ThreadLocal () / / set the data source name public static void setDB (String dbType) {LOG.info ("switch to {} data source", dbType); contextHolder.set (dbType);} / get the data source name public static String getDB () {return (contextHolder.get ());} / clear the data source name public static void clearDB () {contextHolder.remove ();}} DynamicDataSource

Gets the data source used in execution. Since the data source is stored in ThreadLocal in DataSourceContextHolder, you can get it directly.

/ * get local data source * / public class DynamicDataSource extends AbstractRoutingDataSource {private static final Logger LOG = LoggerFactory.getLogger (DynamicDataSource.class); @ Override protected Object determineCurrentLookupKey () {LOG.info ("data source is {}", DataSourceContextHolder.getDB ()); return DataSourceContextHolder.getDB ();}}

At this point, the functions of integrating quartz and data source switching are completed. Then there is the specific task.

Perform a task

Specific tasks need to inherit from BaseJob and override the specific tasks that need to be performed in the execute method.

Execute@Slf4j@Servicepublic class ReadNumJob extends BaseJob {@ Autowired private RedisService redisService; @ Autowired private JdbcTemplate jdbcTemplate; private final Logger LOG = LoggerFactory.getLogger (ReadNumJob.class); @ Override public void execute (JobExecutionContext context) {doSomething ();}} specify the data source

Then specify the data source used by the task when adding the task

ReadNumJob job = new ReadNumJob (); job.setJobName ("test"); job.setJobGroup ("hys"); job.setDescription ("test"); / / specify the data source job.getDataMap (). Put ("dataSource", DataSourceEnum.DB1.getName (); job.setCron_Expression ("0 * / 1 *?"); try {jobAndTriggerService.addJob (job);} catch (SchedulerException e) {e.printStackTrace () } "Spring Boot Integration quartz how to implement timed tasks and support switching task data sources" is introduced here, thank you for reading. If you want to know more about the industry, you can follow the website, the editor will output more high-quality practical articles for you!

Welcome to subscribe "Shulou Technology Information " to get latest news, interesting things and hot topics in the IT industry, and controls the hottest and latest Internet news, technology news and IT industry trends.

Views: 0

*The comments in the above article only represent the author's personal views and do not represent the views and positions of this website. If you have more insights, please feel free to contribute and share.

Share To

Internet Technology

Wechat

© 2024 shulou.com SLNews company. All rights reserved.

12
Report