文章详情

短信预约-IT技能 免费直播动态提醒

请输入下面的图形验证码

提交验证

短信预约提醒成功

聊一聊时间轮的实现

2024-12-03 00:09

关注

上一篇我们讲了定时器的几种实现,分析了在大数据量高并发的场景下这几种实现方式就有点力不从心了,从而引出时间轮这种数据结构。在netty 和kafka 这两种优秀的中间件中,都有时间轮的实现。文章最后,我们模拟kafka 中scala 的代码实现java版的时间轮。

Netty 的时间轮实现

接口定义

Netty 的实现自定义了一个超时器的接口io.netty.util.Timer,其方法如下:

  1. public interface Timer 
  2.     //新增一个延时任务,入参为定时任务TimerTask,和对应的延迟时间 
  3.     Timeout newTimeout(TimerTask task, long delay, TimeUnit unit); 
  4.     //停止时间轮的运行,并且返回所有未被触发的延时任务 
  5.     Set < Timeout > stop(); 
  6. public interface Timeout 
  7.     Timer timer(); 
  8.     TimerTask task(); 
  9.     boolean isExpired(); 
  10.     boolean isCancelled(); 
  11.     boolean cancel(); 

Timeout接口是对延迟任务的一个封装,其接口方法说明其实现内部需要维持该延迟任务的状态。后续我们分析其实现内部代码时可以更容易的看到。

Timer接口有唯一实现HashedWheelTimer。首先来看其构造方法,如下:

  1. public HashedWheelTimer(ThreadFactory threadFactory, long tickDuration, TimeUnit unit, int ticksPerWheel, boolean leakDetection, long maxPendingTimeouts) 
  2.     //省略代码,省略参数非空检查内容。 
  3.     wheel = createWheel(ticksPerWheel); 
  4.     mask = wheel.length - 1; 
  5.     //省略代码,省略槽位时间范围检查,避免溢出以及小于 1 毫秒。 
  6.     workerThread = threadFactory.newThread(worker); 
  7.     //省略代码,省略资源泄漏追踪设置以及时间轮实例个数检查 

mask 的设计和HashMap一样,通过限制数组的大小为2的次方,利用位运算来替代取模运算,提高性能。

构建循环数组

首先是方法createWheel,用于创建时间轮的核心数据结构,循环数组。来看下其方法内容

  1. private static HashedWheelBucket[] createWheel(int ticksPerWheel) 
  2.     //省略代码,确认 ticksPerWheel 处于正确的区间 
  3.     //将 ticksPerWheel 规范化为 2 的次方幂大小。 
  4.     ticksPerWheel = normalizeTicksPerWheel(ticksPerWheel); 
  5.     HashedWheelBucket[] wheel = new HashedWheelBucket[ticksPerWheel]; 
  6.     for(int i = 0; i < wheel.length; i++) 
  7.     { 
  8.         wheel[i] = new HashedWheelBucket(); 
  9.     } 
  10.     return wheel; 

数组的长度为 2 的次方幂方便进行求商和取余计算。

HashedWheelBucket内部存储着由HashedWheelTimeout节点构成的双向链表,并且存储着链表的头节点和尾结点,方便于任务的提取和插入。

新增延迟任务

方法HashedWheelTimer#newTimeout用于新增延迟任务,下面来看下代码:

  1. public Timeout newTimeout(TimerTask task, long delay, TimeUnit unit) 
  2.     //省略代码,用于参数检查 
  3.     start(); 
  4.     long deadline = System.nanoTime() + unit.toNanos(delay) - startTime; 
  5.     if(delay > 0 && deadline < 0) 
  6.     { 
  7.         deadline = Long.MAX_VALUE; 
  8.     } 
  9.     HashedWheelTimeout timeout = new HashedWheelTimeout(this, task, deadline); 
  10.     timeouts.add(timeout); 
  11.     return timeout; 

可以看到任务并没有直接添加到时间轮中,而是先入了一个 mpsc 队列,我简单说下 mpsc【多生产者单一消费者队列】 是 JCTools 中的并发队列,用在多个生产者可同时访问队列,但只有一个消费者会访问队列的情况。,采用这个模式主要出于提升并发性能考虑,因为这个队列只有线程workerThread会进行任务提取操作。

工作线程如何执行

  1. public void run() 
  2.     {//代码块① 
  3.         startTime = System.nanoTime(); 
  4.         if(startTime == 0) 
  5.         { 
  6.             //使用startTime==0 作为线程进入工作状态模式标识,因此这里重新赋值为1 
  7.             startTime = 1; 
  8.         } 
  9.         //通知外部初始化工作线程的线程,工作线程已经启动完毕 
  10.         startTimeInitialized.countDown(); 
  11.     } 
  12.     {//代码块② 
  13.         do { 
  14.             final long deadline = waitForNextTick(); 
  15.             if(deadline > 0) 
  16.             { 
  17.                 int idx = (int)(tick & mask); 
  18.                 processCancelledTasks(); 
  19.                 HashedWheelBucket bucket = wheel[idx]; 
  20.                 transferTimeoutsToBuckets(); 
  21.                 bucket.expireTimeouts(deadline); 
  22.                 tick++; 
  23.             } 
  24.         } while (WORKER_STATE_UPDATER.get(HashedWheelTimer.this) == WORKER_STATE_STARTED); 
  25.     } 
  26.     {//代码块③ 
  27.         for(HashedWheelBucket bucket: wheel) 
  28.         { 
  29.             bucket.clearTimeouts(unprocessedTimeouts); 
  30.         } 
  31.         for(;;) 
  32.         { 
  33.             HashedWheelTimeout timeout = timeouts.poll(); 
  34.             if(timeout == null
  35.             { 
  36.                 break; 
  37.             } 
  38.             if(!timeout.isCancelled()) 
  39.             { 
  40.                 unprocessedTimeouts.add(timeout); 
  41.             } 
  42.         } 
  43.         processCancelledTasks(); 
  44.     } 

看 waitForNextTick,是如何得到下一次执行时间的。

  1. private long waitForNextTick() 
  2.     long deadline = tickDuration * (tick + 1);//计算下一次需要检查的时间 
  3.     for(;;) 
  4.     { 
  5.         final long currentTime = System.nanoTime() - startTime; 
  6.         long sleepTimeMs = (deadline - currentTime + 999999) / 1000000; 
  7.         if(sleepTimeMs <= 0)//说明时间已经到了 
  8.         { 
  9.             if(currentTime == Long.MIN_VALUE) 
  10.             { 
  11.                 return -Long.MAX_VALUE; 
  12.             } 
  13.             else 
  14.             { 
  15.                 return currentTime; 
  16.             } 
  17.         } 
  18.         //windows 下有bug  sleep 必须是10 的倍数 
  19.         if(PlatformDependent.isWindows()) 
  20.         { 
  21.             sleepTimeMs = sleepTimeMs / 10 * 10; 
  22.         } 
  23.         try 
  24.         { 
  25.             Thread.sleep(sleepTimeMs);// 等待时间到来 
  26.         } 
  27.         catch(InterruptedException ignored) 
  28.         { 
  29.             if(WORKER_STATE_UPDATER.get(HashedWheelTimer.this) == WORKER_STATE_SHUTDOWN) 
  30.             { 
  31.                 return Long.MIN_VALUE; 
  32.             } 
  33.         } 
  34.     } 

简单的说就是通过 tickDuration 和此时已经滴答的次数算出下一次需要检查的时间,时候未到就sleep等着。

任务如何入槽的。

  1. private void transferTimeoutsToBuckets() { 
  2.             //最多处理100000 怕任务延迟 
  3.             for(int i = 0; i < 100000; ++i) { 
  4.                 //从队列里面拿出任务呢 
  5.                 HashedWheelTimer.HashedWheelTimeout timeout = (HashedWheelTimer.HashedWheelTimeout)HashedWheelTimer.this.timeouts.poll(); 
  6.                 if (timeout == null) { 
  7.                     break; 
  8.                 } 
  9.  
  10.                 if (timeout.state() != 1) { 
  11.                     long calculated = timeout.deadline / HashedWheelTimer.this.tickDuration; 
  12.                     //计算排在第几轮 
  13.                     timeout.remainingRounds = (calculated - this.tick) / (long)HashedWheelTimer.this.wheel.length; 
  14.                     long ticks = Math.max(calculated, this.tick); 
  15.                     //计算放在哪个槽中 
  16.                     int stopIndex = (int)(ticks & (long)HashedWheelTimer.this.mask); 
  17.                     HashedWheelTimer.HashedWheelBucket bucket = HashedWheelTimer.this.wheel[stopIndex]; 
  18.                     //入槽,就是链表入队列 
  19.                     bucket.addTimeout(timeout); 
  20.                 } 
  21.             } 
  22.  
  23.         } 

如何执行的

  1. public void expireTimeouts(long deadline) { 
  2.             HashedWheelTimer.HashedWheelTimeout next
  3.             //拿到槽的链表头部 
  4.             for(HashedWheelTimer.HashedWheelTimeout timeout = this.head; timeout != null; timeout = next) { 
  5.                 boolean remove = false
  6.                 if (timeout.remainingRounds <= 0L) {//如果到这轮l  
  7.                     if (timeout.deadline > deadline) { 
  8.                         throw new IllegalStateException(String.format("timeout.deadline (%d) > deadline (%d)", timeout.deadline, deadline)); 
  9.                     } 
  10.  
  11.                     timeout.expire();//执行 
  12.                     remove = true
  13.                 } else if (timeout.isCancelled()) { 
  14.                     remove = true
  15.                 } else { 
  16.                     --timeout.remainingRounds;//轮数-1 
  17.                 } 
  18.  
  19.                 next = timeout.next;//继续下一任务 
  20.                 if (remove) { 
  21.                     this.remove(timeout);//移除完成的任务 
  22.                 } 
  23.             } 
  24.         } 

就是通过轮数和时间双重判断,执行完了移除任务。

小结一下

总体上看 Netty 的实现就是上文说的时间轮通过轮数的实现,完全一致。可以看出时间精度由 TickDuration 把控,并且工作线程的除了处理执行到时的任务还做了其他操作,因此任务不一定会被精准的执行。

而且任务的执行如果不是新起一个线程,或者将任务扔到线程池执行,那么耗时的任务会阻塞下个任务的执行。

并且会有很多无用的 tick 推进,例如 TickDuration 为1秒,此时就一个延迟350秒的任务,那就是有349次无用的操作。出现空推。

但是从另一面来看,如果任务都执行很快(当然你也可以异步执行),并且任务数很多,通过分批执行,并且增删任务的时间复杂度都是O(1)来说。时间轮还是比通过优先队列实现的延时任务来的合适些。

Kafka 中的时间轮

上面我们说到 Kafka 中的时间轮是多层次时间轮实现,总的而言实现和上述说的思路一致。不过细节有些不同,并且做了点优化。

先看看添加任务的方法。在添加的时候就设置任务执行的绝对时间。

Kafka 中的时间轮

上面我们说到 Kafka 中的时间轮是多层次时间轮实现,总的而言实现和上述说的思路一致。不过细节有些不同,并且做了点优化。

先看看添加任务的方法。在添加的时候就设置任务执行的绝对时间。

  1. def add(timerTaskEntry: TimerTaskEntry): Boolean = { 
  2.     val expiration = timerTaskEntry.expirationMs 
  3.  
  4.     if (timerTaskEntry.cancelled) { 
  5.       // Cancelled 
  6.       false 
  7.     } else if (expiration < currentTime + tickMs) { 
  8.       // 如果已经到期 返回false 
  9.       // Already expired 
  10.       false 
  11.     } else if (expiration < currentTime + interval) {//如果在本层范围内 
  12.       // Put in its own bucket 
  13.       val virtualId = expiration / tickMs 
  14.       val bucket = buckets((virtualId % wheelSize.toLong).toInt)//计算槽位 
  15.       bucket.add(timerTaskEntry)//添加到槽内双向链表中 
  16.  
  17.       // Set the bucket expiration time 
  18.       if (bucket.setExpiration(virtualId * tickMs)) {//更新槽时间 
  19.         // The bucket needs to be enqueued because it was an expired bucket 
  20.         // We only need to enqueue the bucket when its expiration time has changed, i.e. the wheel has advanced 
  21.         // and the previous buckets gets reused; further calls to set the expiration within the same wheel cycle 
  22.         // will pass in the same value and hence return false, thus the bucket with the same expiration will not 
  23.         // be enqueued multiple times. 
  24.         queue.offer(bucket)//将槽加入DelayQueue,由DelayQueue来推进执行 
  25.       } 
  26.       true 
  27.     } else { 
  28.       //如果超过本层能表示的延迟时间,则将任务添加到上层。这里看到上层是按需创建的。 
  29.       // Out of the interval. Put it into the parent timer 
  30.       if (overflowWheel == null) addOverflowWheel() 
  31.       overflowWheel.add(timerTaskEntry) 
  32.     } 
  33.   } 

那么时间轮是如何推动的呢?Netty 中是通过固定的时间间隔扫描,时候未到就等待来进行时间轮的推动。上面我们分析到这样会有空推进的情况。

而 Kafka 就利用了空间换时间的思想,通过 DelayQueue,来保存每个槽,通过每个槽的过期时间排序。这样拥有最早需要执行任务的槽会有优先获取。如果时候未到,那么 delayQueue.poll 就会阻塞着,这样就不会有空推进的情况发送。

我们来看下推进的方法。

  1. def advanceClock(timeoutMs: Long): Boolean = { 
  2. //从延迟队列中获取槽 
  3.     var bucket = delayQueue.poll(timeoutMs, TimeUnit.MILLISECONDS) 
  4.     if (bucket != null) { 
  5.       writeLock.lock() 
  6.       try { 
  7.         while (bucket != null) { 
  8.           // 更新每层时间轮的currentTime 
  9.           timingWheel.advanceClock(bucket.getExpiration()) 
  10.           //因为更新了currentTime,进行一波任务的重新插入,来实现任务时间轮的降级 
  11.           bucket.flush(reinsert) 
  12.           //获取下一个槽 
  13.           bucket = delayQueue.poll() 
  14.         } 
  15.       } finally { 
  16.         writeLock.unlock() 
  17.       } 
  18.       true 
  19.     } else { 
  20.       false 
  21.     } 
  22.   } 
  23.    
  24.  // Try to advance the clock 
  25.   def advanceClock(timeMs: Long): Unit = { 
  26.     if (timeMs >= currentTime + tickMs) { 
  27.      // 必须是tickMs 整数倍 
  28.       currentTime = timeMs - (timeMs % tickMs) 
  29.       //推动上层时间轮也更新currentTime 
  30.       // Try to advance the clock of the overflow wheel if present 
  31.       if (overflowWheel != null) overflowWheel.advanceClock(currentTime) 
  32.     } 
  33.   } 

从上面的 add 方法我们知道每次对比都是根据expiration < currentTime + interval 来进行对比的,而advanceClock 就是用来推进更新 currentTime 的。

小结一下

Kafka 用了多层次时间轮来实现,并且是按需创建时间轮,采用任务的绝对时间来判断延期,并且对于每个槽(槽内存放的也是任务的双向链表)都会维护一个过期时间,利用 DelayQueue 来对每个槽的过期时间排序,来进行时间的推进,防止空推进的存在。

每次推进都会更新 currentTime 为当前时间戳,当然做了点微调使得 currentTime 是 tickMs 的整数倍。并且每次推进都会把能降级的任务重新插入降级。

可以看到这里的 DelayQueue 的元素是每个槽,而不是任务,因此数量就少很多了,这应该是权衡了对于槽操作的延时队列的时间复杂度与空推进的影响。

模拟kafka的时间轮实现java版

定时器

  1. public class Timer { 
  2.  
  3.      
  4.     private TimeWheel timeWheel; 
  5.  
  6.      
  7.     private DelayQueue delayQueue = new DelayQueue<>(); 
  8.  
  9.      
  10.     private ExecutorService workerThreadPool; 
  11.  
  12.      
  13.     private ExecutorService bossThreadPool; 
  14.  
  15.      
  16.     public Timer() { 
  17.         timeWheel = new TimeWheel(1000, 2, System.currentTimeMillis(), delayQueue); 
  18.         workerThreadPool = Executors.newFixedThreadPool(100); 
  19.         bossThreadPool = Executors.newFixedThreadPool(1); 
  20.         //20ms获取一次过期任务 
  21.         bossThreadPool.submit(() -> { 
  22.             while (true) { 
  23.                 this.advanceClock(1000); 
  24.             } 
  25.         }); 
  26.     } 
  27.  
  28.      
  29.     public void addTask(TimerTask timerTask) { 
  30.         //添加失败任务直接执行 
  31.         if (!timeWheel.addTask(timerTask)) { 
  32.             workerThreadPool.submit(timerTask.getTask()); 
  33.         } 
  34.     } 
  35.  
  36.      
  37.     private void advanceClock(long timeout) { 
  38.         try { 
  39.             TimerTaskList timerTaskList = delayQueue.poll(timeout, TimeUnit.MILLISECONDS); 
  40.             if (timerTaskList != null) { 
  41.  
  42.                 //推进时间 
  43.                 timeWheel.advanceClock(timerTaskList.getExpiration()); 
  44.                 //执行过期任务(包含降级操作) 
  45.                 timerTaskList.flush(this::addTask); 
  46.             } 
  47.         } catch (Exception e) { 
  48.             e.printStackTrace(); 
  49.         } 
  50.     } 

任务

  1. public class TimerTask { 
  2.  
  3.      
  4.     private long delayMs; 
  5.  
  6.      
  7.     private MyThread task; 
  8.  
  9.      
  10.     protected TimerTaskList timerTaskList; 
  11.  
  12.      
  13.     protected TimerTask next
  14.  
  15.      
  16.     protected TimerTask pre; 
  17.  
  18.      
  19.     public String desc
  20.  
  21.     public TimerTask(long delayMs, MyThread task) { 
  22.         this.delayMs = System.currentTimeMillis() + delayMs; 
  23.         this.task = task; 
  24.         this.timerTaskList = null
  25.         this.next = null
  26.         this.pre = null
  27.     } 
  28.  
  29.     public MyThread getTask() { 
  30.         return task; 
  31.     } 
  32.  
  33.     public long getDelayMs() { 
  34.         return delayMs; 
  35.     } 
  36.  
  37.     @Override 
  38.     public String toString() { 
  39.         return desc
  40.     } 

时间槽

  1. public class TimerTaskList implements Delayed { 
  2.  
  3.      
  4.     private AtomicLong expiration = new AtomicLong(-1L); 
  5.  
  6.      
  7.     private TimerTask root = new TimerTask(-1L, null); 
  8.  
  9.     { 
  10.         root.pre = root; 
  11.         root.next = root; 
  12.     } 
  13.  
  14.      
  15.     public boolean setExpiration(long expire) { 
  16.         return expiration.getAndSet(expire) != expire; 
  17.     } 
  18.  
  19.      
  20.     public long getExpiration() { 
  21.         return expiration.get(); 
  22.     } 
  23.  
  24.      
  25.     public void addTask(TimerTask timerTask) { 
  26.         synchronized (this) { 
  27.             if (timerTask.timerTaskList == null) { 
  28.                 timerTask.timerTaskList = this; 
  29.                 TimerTask tail = root.pre; 
  30.                 timerTask.next = root; 
  31.                 timerTask.pre = tail; 
  32.                 tail.next = timerTask; 
  33.                 root.pre = timerTask; 
  34.             } 
  35.         } 
  36.     } 
  37.  
  38.      
  39.     public void removeTask(TimerTask timerTask) { 
  40.         synchronized (this) { 
  41.             if (timerTask.timerTaskList.equals(this)) { 
  42.                 timerTask.next.pre = timerTask.pre; 
  43.                 timerTask.pre.next = timerTask.next
  44.                 timerTask.timerTaskList = null
  45.                 timerTask.next = null
  46.                 timerTask.pre = null
  47.             } 
  48.         } 
  49.     } 
  50.  
  51.      
  52.     public synchronized void flush(Consumer flush) { 
  53.         TimerTask timerTask = root.next
  54.         while (!timerTask.equals(root)) { 
  55.             this.removeTask(timerTask); 
  56.             flush.accept(timerTask); 
  57.             timerTask = root.next
  58.         } 
  59.         expiration.set(-1L); 
  60.     } 
  61.  
  62.     @Override 
  63.     public long getDelay(TimeUnit unit) { 
  64.         return Math.max(0, unit.convert(expiration.get() - System.currentTimeMillis(), TimeUnit.MILLISECONDS)); 
  65.     } 
  66.  
  67.     @Override 
  68.     public int compareTo(Delayed o) { 
  69.         if (o instanceof TimerTaskList) { 
  70.             return Long.compare(expiration.get(), ((TimerTaskList) o).expiration.get()); 
  71.         } 
  72.         return 0; 
  73.     } 

时间轮

  1. public class TimeWheel { 
  2.  
  3.      
  4.     private long tickMs; 
  5.  
  6.      
  7.     private int wheelSize; 
  8.  
  9.      
  10.     private long interval; 
  11.  
  12.      
  13.     private TimerTaskList[] timerTaskLists; 
  14.  
  15.      
  16.     private long currentTime; 
  17.  
  18.      
  19.     private volatile TimeWheel overflowWheel; 
  20.  
  21.      
  22.     private DelayQueue delayQueue; 
  23.  
  24.     public TimeWheel(long tickMs, int wheelSize, long currentTime, DelayQueue delayQueue) { 
  25.         this.currentTime = currentTime; 
  26.         this.tickMs = tickMs; 
  27.         this.wheelSize = wheelSize; 
  28.         this.interval = tickMs * wheelSize; 
  29.         this.timerTaskLists = new TimerTaskList[wheelSize]; 
  30.         //currentTime为tickMs的整数倍 这里做取整操作 
  31.         this.currentTime = currentTime - (currentTime % tickMs); 
  32.         this.delayQueue = delayQueue; 
  33.         for (int i = 0; i < wheelSize; i++) { 
  34.             timerTaskLists[i] = new TimerTaskList(); 
  35.         } 
  36.     } 
  37.  
  38.      
  39.     private TimeWheel getOverflowWheel() { 
  40.         if (overflowWheel == null) { 
  41.             synchronized (this) { 
  42.                 if (overflowWheel == null) { 
  43.                     overflowWheel = new TimeWheel(interval, wheelSize, currentTime, delayQueue); 
  44.                 } 
  45.             } 
  46.         } 
  47.         return overflowWheel; 
  48.     } 
  49.  
  50.      
  51.     public boolean addTask(TimerTask timerTask) { 
  52.         long expiration = timerTask.getDelayMs(); 
  53.         //过期任务直接执行 
  54.         if (expiration < currentTime + tickMs) { 
  55.             return false
  56.         } else if (expiration < currentTime + interval) { 
  57.             //当前时间轮可以容纳该任务 加入时间槽 
  58.             Long virtualId = expiration / tickMs; 
  59.             int index = (int) (virtualId % wheelSize); 
  60.             System.out.println("tickMs:" + tickMs + "------index:" + index + "------expiration:" + expiration); 
  61.             TimerTaskList timerTaskList = timerTaskLists[index]; 
  62.             timerTaskList.addTask(timerTask); 
  63.             if (timerTaskList.setExpiration(virtualId * tickMs)) { 
  64.                 //添加到delayQueue中 
  65.                 delayQueue.offer(timerTaskList); 
  66.             } 
  67.         } else { 
  68.             //放到上一层的时间轮 
  69.             TimeWheel timeWheel = getOverflowWheel(); 
  70.             timeWheel.addTask(timerTask); 
  71.         } 
  72.         return true
  73.     } 
  74.  
  75.      
  76.     public void advanceClock(long timestamp) { 
  77.         if (timestamp >= currentTime + tickMs) { 
  78.             currentTime = timestamp - (timestamp % tickMs); 
  79.             if (overflowWheel != null) { 
  80.                 //推进上层时间轮时间 
  81.                 System.out.println("推进上层时间轮时间 time="+System.currentTimeMillis()); 
  82.                 this.getOverflowWheel().advanceClock(timestamp); 
  83.             } 
  84.         } 
  85.     } 

我们来模拟一个请求,超时和不超时的情况

首先定义一个Mythread 类,用于设置任务超时的值。

  1. public class MyThread implements Runnable{ 
  2.     CompletableFuture cf; 
  3.     public MyThread(CompletableFuture  cf){ 
  4.         this.cf = cf; 
  5.     } 
  6.     public void run(){ 
  7.         if (!cf.isDone()) { 
  8.             cf.complete("超时"); 
  9.         } 
  10.     } 

模拟超时

  1. public static void main(String[] args) throws Exception{ 
  2.         Timer timer = new Timer(); 
  3.         CompletableFuture base =CompletableFuture.supplyAsync(()->{ 
  4.             try { 
  5.                 Thread.sleep(3000); 
  6.             } catch (InterruptedException e) { 
  7.                 e.printStackTrace(); 
  8.             } 
  9.             return  "正常返回"
  10.         }); 
  11.         TimerTask timerTask2 = new TimerTask(1000, new MyThread(base)); 
  12.         timer.addTask(timerTask2); 
  13.         System.out.println("base.get==="+base.get()); 
  14.     } 

模拟正常返回

  1. public static void main(String[] args) throws Exception{ 
  2.         Timer timer = new Timer(); 
  3.         CompletableFuture base =CompletableFuture.supplyAsync(()->{ 
  4.             try { 
  5.                 Thread.sleep(300); 
  6.             } catch (InterruptedException e) { 
  7.                 e.printStackTrace(); 
  8.             } 
  9.             return  "正常返回"
  10.         }); 
  11.         TimerTask timerTask2 = new TimerTask(2000, new MyThread(base)); 
  12.         timer.addTask(timerTask2); 
  13.         System.out.println("base.get==="+base.get()); 
  14.     } 

本文转载自微信公众号「小汪哥写代码」,可以通过以下二维码关注。转载本文请联系小汪哥写代码公众号。

 

来源:小汪哥写代码内容投诉

免责声明:

① 本站未注明“稿件来源”的信息均来自网络整理。其文字、图片和音视频稿件的所属权归原作者所有。本站收集整理出于非商业性的教育和科研之目的,并不意味着本站赞同其观点或证实其内容的真实性。仅作为临时的测试数据,供内部测试之用。本站并未授权任何人以任何方式主动获取本站任何信息。

② 本站未注明“稿件来源”的临时测试数据将在测试完成后最终做删除处理。有问题或投稿请发送至: 邮箱/279061341@qq.com QQ/279061341

软考中级精品资料免费领

  • 历年真题答案解析
  • 备考技巧名师总结
  • 高频考点精准押题
  • 2024年上半年信息系统项目管理师第二批次真题及答案解析(完整版)

    难度     813人已做
    查看
  • 【考后总结】2024年5月26日信息系统项目管理师第2批次考情分析

    难度     354人已做
    查看
  • 【考后总结】2024年5月25日信息系统项目管理师第1批次考情分析

    难度     318人已做
    查看
  • 2024年上半年软考高项第一、二批次真题考点汇总(完整版)

    难度     435人已做
    查看
  • 2024年上半年系统架构设计师考试综合知识真题

    难度     224人已做
    查看

相关文章

发现更多好内容

猜你喜欢

AI推送时光机
位置:首页-资讯-后端开发
咦!没有更多了?去看看其它编程学习网 内容吧
首页课程
资料下载
问答资讯