org.springframework.scheduling.TaskScheduler.scheduleAtFixedRate()方法的使用及代码示例

x33g5p2x  于2022-01-29 转载在 其他  
字(12.1k)|赞(0)|评价(0)|浏览(148)

本文整理了Java中org.springframework.scheduling.TaskScheduler.scheduleAtFixedRate()方法的一些代码示例,展示了TaskScheduler.scheduleAtFixedRate()的具体用法。这些代码示例主要来源于Github/Stackoverflow/Maven等平台,是从一些精选项目中提取出来的代码,具有较强的参考意义,能在一定程度帮忙到你。TaskScheduler.scheduleAtFixedRate()方法的具体详情如下:
包路径:org.springframework.scheduling.TaskScheduler
类名称:TaskScheduler
方法名:scheduleAtFixedRate

TaskScheduler.scheduleAtFixedRate介绍

[英]Schedule the given Runnable, starting as soon as possible and invoking it with the given period.

Execution will end once the scheduler shuts down or the returned ScheduledFuture gets cancelled.
[中]安排给定的Runnable,尽快开始并在给定的时间段内调用它。
一旦调度程序关闭或返回的ScheduledFuture被取消,执行将结束。

代码示例

代码示例来源:origin: spring-projects/spring-framework

  1. /**
  2. * Schedule the given {@link Runnable}, starting as soon as possible and
  3. * invoking it with the given period.
  4. * <p>Execution will end once the scheduler shuts down or the returned
  5. * {@link ScheduledFuture} gets cancelled.
  6. * @param task the Runnable to execute whenever the trigger fires
  7. * @param period the interval between successive executions of the task
  8. * @return a {@link ScheduledFuture} representing pending completion of the task
  9. * @throws org.springframework.core.task.TaskRejectedException if the given task was not accepted
  10. * for internal reasons (e.g. a pool overload handling policy or a pool shutdown in progress)
  11. * @since 5.0
  12. * @see #scheduleAtFixedRate(Runnable, long)
  13. */
  14. default ScheduledFuture<?> scheduleAtFixedRate(Runnable task, Duration period) {
  15. return scheduleAtFixedRate(task, period.toMillis());
  16. }

代码示例来源:origin: spring-projects/spring-security

  1. @Override
  2. public ScheduledFuture<?> scheduleAtFixedRate(Runnable task, Date startTime, long period) {
  3. return taskScheduler.scheduleAtFixedRate(task, startTime, period);
  4. }

代码示例来源:origin: spring-projects/spring-security

  1. @Override
  2. public ScheduledFuture<?> scheduleAtFixedRate(Runnable task, long period) {
  3. return taskScheduler.scheduleAtFixedRate(task, period);
  4. }

代码示例来源:origin: spring-projects/spring-framework

  1. /**
  2. * Schedule the given {@link Runnable}, invoking it at the specified execution time
  3. * and subsequently with the given period.
  4. * <p>Execution will end once the scheduler shuts down or the returned
  5. * {@link ScheduledFuture} gets cancelled.
  6. * @param task the Runnable to execute whenever the trigger fires
  7. * @param startTime the desired first execution time for the task
  8. * (if this is in the past, the task will be executed immediately, i.e. as soon as possible)
  9. * @param period the interval between successive executions of the task
  10. * @return a {@link ScheduledFuture} representing pending completion of the task
  11. * @throws org.springframework.core.task.TaskRejectedException if the given task was not accepted
  12. * for internal reasons (e.g. a pool overload handling policy or a pool shutdown in progress)
  13. * @since 5.0
  14. * @see #scheduleAtFixedRate(Runnable, Date, long)
  15. */
  16. default ScheduledFuture<?> scheduleAtFixedRate(Runnable task, Instant startTime, Duration period) {
  17. return scheduleAtFixedRate(task, Date.from(startTime), period.toMillis());
  18. }

代码示例来源:origin: org.springframework/spring-context

  1. /**
  2. * Schedule the given {@link Runnable}, starting as soon as possible and
  3. * invoking it with the given period.
  4. * <p>Execution will end once the scheduler shuts down or the returned
  5. * {@link ScheduledFuture} gets cancelled.
  6. * @param task the Runnable to execute whenever the trigger fires
  7. * @param period the interval between successive executions of the task
  8. * @return a {@link ScheduledFuture} representing pending completion of the task
  9. * @throws org.springframework.core.task.TaskRejectedException if the given task was not accepted
  10. * for internal reasons (e.g. a pool overload handling policy or a pool shutdown in progress)
  11. * @since 5.0
  12. * @see #scheduleAtFixedRate(Runnable, long)
  13. */
  14. default ScheduledFuture<?> scheduleAtFixedRate(Runnable task, Duration period) {
  15. return scheduleAtFixedRate(task, period.toMillis());
  16. }

代码示例来源:origin: org.springframework/spring-context

  1. /**
  2. * Schedule the given {@link Runnable}, invoking it at the specified execution time
  3. * and subsequently with the given period.
  4. * <p>Execution will end once the scheduler shuts down or the returned
  5. * {@link ScheduledFuture} gets cancelled.
  6. * @param task the Runnable to execute whenever the trigger fires
  7. * @param startTime the desired first execution time for the task
  8. * (if this is in the past, the task will be executed immediately, i.e. as soon as possible)
  9. * @param period the interval between successive executions of the task
  10. * @return a {@link ScheduledFuture} representing pending completion of the task
  11. * @throws org.springframework.core.task.TaskRejectedException if the given task was not accepted
  12. * for internal reasons (e.g. a pool overload handling policy or a pool shutdown in progress)
  13. * @since 5.0
  14. * @see #scheduleAtFixedRate(Runnable, Date, long)
  15. */
  16. default ScheduledFuture<?> scheduleAtFixedRate(Runnable task, Instant startTime, Duration period) {
  17. return scheduleAtFixedRate(task, Date.from(startTime), period.toMillis());
  18. }

代码示例来源:origin: spring-projects/spring-framework

  1. private void scheduleSessionTask() {
  2. synchronized (this.sessions) {
  3. if (this.sessionCleanupTask != null) {
  4. return;
  5. }
  6. this.sessionCleanupTask = getTaskScheduler().scheduleAtFixedRate(() -> {
  7. List<String> removedIds = new ArrayList<>();
  8. for (SockJsSession session : this.sessions.values()) {
  9. try {
  10. if (session.getTimeSinceLastActive() > getDisconnectDelay()) {
  11. this.sessions.remove(session.getId());
  12. removedIds.add(session.getId());
  13. session.close();
  14. }
  15. }
  16. catch (Throwable ex) {
  17. // Could be part of normal workflow (e.g. browser tab closed)
  18. logger.debug("Failed to close " + session, ex);
  19. }
  20. }
  21. if (logger.isDebugEnabled() && !removedIds.isEmpty()) {
  22. logger.debug("Closed " + removedIds.size() + " sessions: " + removedIds);
  23. }
  24. }, getDisconnectDelay());
  25. }
  26. }

代码示例来源:origin: spring-projects/spring-framework

  1. Date startTime = new Date(System.currentTimeMillis() + task.getInitialDelay());
  2. scheduledTask.future =
  3. this.taskScheduler.scheduleAtFixedRate(task.getRunnable(), startTime, task.getInterval());
  4. this.taskScheduler.scheduleAtFixedRate(task.getRunnable(), task.getInterval());

代码示例来源:origin: org.springframework/spring-context

  1. Date startTime = new Date(System.currentTimeMillis() + task.getInitialDelay());
  2. scheduledTask.future =
  3. this.taskScheduler.scheduleAtFixedRate(task.getRunnable(), startTime, task.getInterval());
  4. this.taskScheduler.scheduleAtFixedRate(task.getRunnable(), task.getInterval());

代码示例来源:origin: spring-projects/spring-security

  1. @Test
  2. public void testScheduleAtFixedRateWithRunnableAndDate() {
  3. Date date = new Date(1544751374L);
  4. Duration duration = Duration.ofSeconds(4L);
  5. delegatingSecurityContextTaskScheduler.scheduleAtFixedRate(runnable, date, 1000L);
  6. verify(scheduler).scheduleAtFixedRate(isA(Runnable.class), isA(Date.class), eq(1000L));
  7. }

代码示例来源:origin: spring-projects/spring-security

  1. @Test
  2. public void testScheduleAtFixedRateWithRunnableAndLong() {
  3. delegatingSecurityContextTaskScheduler.scheduleAtFixedRate(runnable, 1000L);
  4. verify(scheduler).scheduleAtFixedRate(isA(Runnable.class), eq(1000L));
  5. }
  6. }

代码示例来源:origin: Netflix/genie

  1. /**
  2. * {@inheritDoc}
  3. */
  4. @Override
  5. public synchronized void start(@NotBlank final String jobId) {
  6. if (StringUtils.isNotBlank(this.claimedJobId)) {
  7. throw new IllegalStateException("Previously started with a different job id");
  8. }
  9. this.claimedJobId = jobId;
  10. this.heartBeatMessage = AgentHeartBeat.newBuilder()
  11. .setClaimedJobId(claimedJobId)
  12. .build();
  13. this.heartbeatFuture = taskScheduler.scheduleAtFixedRate(
  14. this::sendHeartBeatTask,
  15. HEART_BEAT_PERIOD_MILLIS
  16. );
  17. this.requestObserver = client.heartbeat(new ResponseObserver(this));
  18. }

代码示例来源:origin: spring-projects/spring-framework

  1. @Test
  2. public void handleTransportRequestXhr() throws Exception {
  3. String sockJsPath = sessionUrlPrefix + "xhr";
  4. setRequest("POST", sockJsPrefix + sockJsPath);
  5. this.service.handleRequest(this.request, this.response, sockJsPath, this.wsHandler);
  6. assertEquals(200, this.servletResponse.getStatus());
  7. verify(this.xhrHandler).handleRequest(this.request, this.response, this.wsHandler, this.session);
  8. verify(taskScheduler).scheduleAtFixedRate(any(Runnable.class), eq(service.getDisconnectDelay()));
  9. assertEquals("no-store, no-cache, must-revalidate, max-age=0", this.response.getHeaders().getCacheControl());
  10. assertNull(this.servletResponse.getHeader(HttpHeaders.ACCESS_CONTROL_ALLOW_ORIGIN));
  11. assertNull(this.servletResponse.getHeader(HttpHeaders.ACCESS_CONTROL_ALLOW_CREDENTIALS));
  12. }

代码示例来源:origin: org.springframework.boot/spring-boot-actuator

  1. /**
  2. * Create a new {@link PrometheusPushGatewayManager} instance.
  3. * @param pushGateway the source push gateway
  4. * @param registry the collector registry to push
  5. * @param scheduler the scheduler used for operations
  6. * @param pushRate the rate at which push operations occur
  7. * @param job the job ID for the operation
  8. * @param groupingKey an optional set of grouping keys for the operation
  9. * @param shutdownOperation the shutdown operation that should be performed when
  10. * context is closed.
  11. */
  12. public PrometheusPushGatewayManager(PushGateway pushGateway,
  13. CollectorRegistry registry, TaskScheduler scheduler, Duration pushRate,
  14. String job, Map<String, String> groupingKey,
  15. ShutdownOperation shutdownOperation) {
  16. Assert.notNull(pushGateway, "PushGateway must not be null");
  17. Assert.notNull(registry, "Registry must not be null");
  18. Assert.notNull(scheduler, "Scheduler must not be null");
  19. Assert.notNull(pushRate, "PushRate must not be null");
  20. Assert.hasLength(job, "Job must not be empty");
  21. this.pushGateway = pushGateway;
  22. this.registry = registry;
  23. this.job = job;
  24. this.groupingKey = groupingKey;
  25. this.shutdownOperation = (shutdownOperation != null) ? shutdownOperation
  26. : ShutdownOperation.NONE;
  27. this.scheduler = scheduler;
  28. this.scheduled = this.scheduler.scheduleAtFixedRate(this::push, pushRate);
  29. }

代码示例来源:origin: spring-projects/spring-integration

  1. @Override
  2. public void start() {
  3. if (this.flushTask == null && FileExistsMode.APPEND_NO_FLUSH.equals(this.fileExistsMode)) {
  4. TaskScheduler taskScheduler = getTaskScheduler();
  5. Assert.state(taskScheduler != null, "'taskScheduler' is required for FileExistsMode.APPEND_NO_FLUSH");
  6. this.flushTask = taskScheduler.scheduleAtFixedRate(new Flusher(), this.flushInterval / 3); // NOSONAR
  7. }
  8. }

代码示例来源:origin: spring-projects/spring-integration

  1. @Override
  2. public void start() {
  3. synchronized (this.lifecycleMonitor) {
  4. if (!this.active) {
  5. this.active = true;
  6. if (this.clientConnectionFactory != null) {
  7. this.clientConnectionFactory.start();
  8. }
  9. if (this.serverConnectionFactory != null) {
  10. this.serverConnectionFactory.start();
  11. }
  12. if (this.isClientMode) {
  13. Assert.notNull(this.clientConnectionFactory,
  14. "For client-mode, connection factory must be type='client'");
  15. ClientModeConnectionManager manager =
  16. new ClientModeConnectionManager(this.clientConnectionFactory);
  17. this.clientModeConnectionManager = manager;
  18. Assert.state(getTaskScheduler() != null, "Client mode requires a task scheduler");
  19. this.scheduledFuture = getTaskScheduler().scheduleAtFixedRate(manager, this.retryInterval);
  20. }
  21. }
  22. }
  23. }

代码示例来源:origin: spring-projects/spring-integration

  1. @Override // protected by super#lifecycleLock
  2. protected void doStart() {
  3. super.doStart();
  4. if (!this.active) {
  5. this.active = true;
  6. this.shuttingDown = false;
  7. if (this.serverConnectionFactory != null) {
  8. this.serverConnectionFactory.start();
  9. }
  10. if (this.clientConnectionFactory != null) {
  11. this.clientConnectionFactory.start();
  12. }
  13. if (this.isClientMode) {
  14. ClientModeConnectionManager manager = new ClientModeConnectionManager(
  15. this.clientConnectionFactory);
  16. this.clientModeConnectionManager = manager;
  17. Assert.state(this.getTaskScheduler() != null, "Client mode requires a task scheduler");
  18. this.scheduledFuture = this.getTaskScheduler().scheduleAtFixedRate(manager, this.retryInterval);
  19. }
  20. }
  21. }

代码示例来源:origin: spring-projects/spring-integration

  1. @Override // protected by super#lifecycleLock
  2. protected void doStart() {
  3. super.doStart();
  4. if (!this.active) {
  5. this.active = true;
  6. this.shuttingDown = false;
  7. if (this.serverConnectionFactory != null) {
  8. this.serverConnectionFactory.start();
  9. }
  10. if (this.clientConnectionFactory != null) {
  11. this.clientConnectionFactory.start();
  12. }
  13. if (this.isClientMode) {
  14. ClientModeConnectionManager manager = new ClientModeConnectionManager(
  15. this.clientConnectionFactory);
  16. this.clientModeConnectionManager = manager;
  17. Assert.state(this.getTaskScheduler() != null, "Client mode requires a task scheduler");
  18. this.scheduledFuture = this.getTaskScheduler().scheduleAtFixedRate(manager, this.retryInterval);
  19. }
  20. }
  21. }

代码示例来源:origin: spring-projects/spring-integration

  1. this.idleTask = getTaskScheduler().scheduleAtFixedRate(new IdleContainerStopper(),
  2. this.idleReplyContainerTimeout / 2);

代码示例来源:origin: spring-cloud/spring-cloud-consul

  1. /**
  2. * Add a service to the checks loop.
  3. */
  4. public void add(String instanceId) {
  5. ScheduledFuture task = scheduler.scheduleAtFixedRate(new ConsulHeartbeatTask(
  6. instanceId), configuration.computeHearbeatInterval()
  7. .toStandardDuration().getMillis());
  8. ScheduledFuture previousTask = serviceHeartbeats.put(instanceId, task);
  9. if (previousTask != null) {
  10. previousTask.cancel(true);
  11. }
  12. }

相关文章