重学Java并发编程—剖析线程池的使用与组成

重学Java并发编程

代码GitHub地址 github.com/imyiren/con…

  1. 刨根问底搞懂创建线程到底有几种方法?
  2. 如何正确得启动和停止一个线程 最佳实践与源码分析
  3. 多案例理解Object的wait,notify,notifyAll与Thread的sleep,yield,join等方法
  4. 了解线程属性,如何处理子线程异常
  5. 多线程安全和性能问题
  6. JMM(Java内存模型)在并发中的原理与应用
  7. 深入理解死锁问题及其解决方案
  8. 剖析线程池的使用与组成

1. 线程池介绍

1.1 为什么使用线程池

  1. 如果不适用线程池来使用线程会有什么坏处?
  • 反复创建线程的开销大
  • 过多线程会占用太多内存
  1. 使用线程池的好处
  • 加快响应速度,不用反复创建和销毁线程
  • 可以合理利用CPU和内存,可以通过线程池来掌控
  • 统一资源管理,当任务多了,我们就可以利用线程池来统一操作。

1.2 适用线程池的场合

  • 服务器接收请求量大,我们可以通过线程池来复用线程,减少线程的创建和销毁开销。
  • 实际开发中我们推荐线程都用线程池来管理。

2. 线程池参数详解

2.1 线程池的参数列表

参数名称 类型 解释
corePoolSize int 核心线程数
maxPoolSize int 最大线程数
keepAliveTime long 保持存活时间
workQueue BlockingQueue 任务储存队列
threadFactory ThreadFactory 线程池创建新线程的工厂类
Handler RejectedExecutionHandler 任务执行的拒绝策略
  • corePoolSize:线程池在完成初始化后,默认线程池没有任何线程,当任务到来,就会创建新的线程去执行任务,直到corePoolSize满。
  • maxPoolSize:线程池在一定情况下回再核心线程的基础上,额外增加一些线程,线程数的上线就是maxPoolSize

2.2 corePoolSize与maxPoolSize控制添加线程的过程:

  1. 线程数小于corePoolSize,即使其他工作线程处于空闲状态,也会去创建一个新线程来运行任务
  2. 如果线程数量等于或者大于了corePoolSize,但是少于maxPoolSize,就放入任务队列(BlockingQueue)中。
  3. 如果队列满了,并且线程小于maxPoolSize,则创建新线程来运行任务
  4. 如果队列满了,并且线程数量到了maxPoolSize,就执行拒绝策略

  • 线程池增减的特点

    • 如果corePoolSize和maxPoolSize设置为相同,则线程池大小就为固定值

    • 线程池希望保持较少的线程数量,只有队列满的情况下才会去增加线程

    • 如果maxPoolSize设置为很高,如:Integer.MAX_VALUE,由于几乎达不到这个值,则可以允许线程容纳任意数量的并发任务

    • 因为只有队列满才会创建高于corePoolSize的线程,所以如果使用无界队列比如LinkedBlockingQueue,那线程数就不会超过corePoolSize

2.2 KeepAliveTime 保持存活时间

  • 如果线程池当前线程数量多于corePoolSize,则多出来的线程当空闲时间超过了KeepAliveTime的时候,就会被终止。
  • 如果不通过allowCoreThreadTimeOut(boolean)设置allowCoreThreadTimeOut参数,corePoolSize的线程,是不会被终止的。

2.3 threadFactory 线程工厂

  • 新的线程是由ThreadFactory创建。
  • Executors默认使用Executors.defaultThreadFactory()创建,切创建出来的线程都在一个线程组,线程优先级都为Thread.NORM_PRIORITY也就是5,不是守护线程。
  • 如果自己指定ThreadFactory,则可以指定线程名、线程组、优先级、守护线程等参数

2.4 workQueue 工作队列

  • 常见的队列:
    • 直接交换:SynchronousQueue,它内部只能包含一个元素的队列。插入元素到队列的线程被阻塞,直到另一个线程从队列中获取了队列中存储的元素。同样,如果线程尝试获取元素并且当前不存在任何元素,则该线程将被阻塞,直到线程将元素插入队列。
    • 无界队列:LinkedBlockingQueue,因为它是链表结构,所以它不会被塞满。设置成这种队列,maxPoolSize就会是失效了,但是如果任务数量猛增容易造成OOM
    • 有界队列:ArrayBlockingQueue,它是有最大值的一个队列,如果队列满了且maxPoolSize大于corePoolSize就会去创建新的线程来执行任务。

3. 线程池创建实例

3.1 使用Executors创建线程池

  1. FixedThreadPool
/**
 * FixedThreadPool
 * @author yiren
 */
public class FixedThreadPool {
    public static void main(String[] args) {
        ExecutorService executorService = Executors.newFixedThreadPool(4);
        for (int i = 0; i < 1000; i++) {
            executorService.execute(() -> {
                try {
                    TimeUnit.MILLISECONDS.sleep(500);
                } catch (InterruptedException e) {
                    e.printStackTrace();
                }
                System.out.println(Thread.currentThread().getName());
            });
        }
    }
}
复制代码
...
pool-1-thread-4
pool-1-thread-2
pool-1-thread-4
pool-1-thread-1
pool-1-thread-3
pool-1-thread-2
pool-1-thread-1
pool-1-thread-4
pool-1-thread-3
...
复制代码
  • 我们可以看到控制台,始终只有4个线程来回使用
  • 我们看下源码
public static ExecutorService newFixedThreadPool(int nThreads) {
        return new ThreadPoolExecutor(nThreads, nThreads,
                                      0L, TimeUnit.MILLISECONDS,
                                      new LinkedBlockingQueue<Runnable>());
    }
复制代码
  • 里面实际创建的就是ThreadPoolExecutor然后参数的coremax设置成了相同值,并且工作队列是无界队列。所以不会创建超过corePoolSize的线程数量。
  • 如果队列过长,会造成OOM
/**
 * FixedThreadPool OOM
 * -Xmx8m -Xms8m
 * @author yiren
 */
public class FixedThreadPoolOom {
    public static void main(String[] args) {
        ExecutorService executorService = Executors.newFixedThreadPool(1);
        Runnable runnable = () -> {
            try {
                Thread.sleep(Integer.MAX_VALUE);
            } catch (InterruptedException e) {
                e.printStackTrace();
            }
        };

        for (int i = 0; i < Integer.MAX_VALUE; i++) {
            executorService.execute(runnable);
        }
    }
}
复制代码
Exception in thread "main" java.lang.OutOfMemoryError: GC overhead limit exceeded
	at java.util.concurrent.LinkedBlockingQueue.offer(LinkedBlockingQueue.java:416)
	at java.util.concurrent.ThreadPoolExecutor.execute(ThreadPoolExecutor.java:1371)
	at com.imyiren.concurrency.threadpool.FixedThreadPoolOom.main(FixedThreadPoolOom.java:23)

复制代码
  1. SingleThreadExecutor
    public static ExecutorService newSingleThreadExecutor() {
        return new FinalizableDelegatedExecutorService
            (new ThreadPoolExecutor(1, 1,
                                    0L, TimeUnit.MILLISECONDS,
                                    new LinkedBlockingQueue<Runnable>()));
    }
复制代码
  • 可见方法内,coremax都为1,是单线程线程池,且它的阻塞队列也是无界队列链表。等同于newFixedThreadPool(1),这里就不演示了。
  1. CachedThreadPool
public static ExecutorService newCachedThreadPool() {
        return new ThreadPoolExecutor(0, Integer.MAX_VALUE,
                                      60L, TimeUnit.SECONDS,
                                      new SynchronousQueue<Runnable>());
    }
复制代码
  • CachedThreadPool的core为0,maxInteger.MAX_VALUE,并且工作队列为直接交换队列,所以来多少线程就创建多少线程,并且这个线程任务使用结束过后,不会立马终止,会等待60s,做一个缓存处理,提高利用率,过时不使用就会自己销毁。由于maxInteger.MAX_VALUE线程数量特别多也容易OOM
  1. ScheduledThreadPool
  • 按照时间周期执行任务
    public static ScheduledExecutorService newScheduledThreadPool(int corePoolSize) {
        return new ScheduledThreadPoolExecutor(corePoolSize);
    }

    public ScheduledThreadPoolExecutor(int corePoolSize) {
        super(corePoolSize, Integer.MAX_VALUE, 0, NANOSECONDS,
              new DelayedWorkQueue());
    }

    public ThreadPoolExecutor(int corePoolSize,
                              int maximumPoolSize,
                              long keepAliveTime,
                              TimeUnit unit,
                              BlockingQueue<Runnable> workQueue) {
        this(corePoolSize, maximumPoolSize, keepAliveTime, unit, workQueue,
             Executors.defaultThreadFactory(), defaultHandler);
    }
复制代码
  • 由上面源码我们可以看到,newScheduledThreadPool只需要指定核心线程数,创建了一个ThreadPoolExecutor的子类ScheduledThreadPoolExecutor,并且它的工作队列是一个延迟队列。
  • 我们看一下如何使用
/**
 * ScheduledThreadPool
 * @author yiren
 */
public class ScheduledThreadPool {
    public static void main(String[] args) {
        ScheduledExecutorService scheduledExecutorService = Executors.newScheduledThreadPool(2);
        System.out.println(LocalDateTime.now());
        scheduledExecutorService.schedule(() -> System.out.println(LocalDateTime.now() + " "+ Thread.currentThread().getName() + " delay 5s"), 5, TimeUnit.SECONDS);

        scheduledExecutorService.scheduleAtFixedRate(() -> System.out.println(LocalDateTime.now() + " "+ Thread.currentThread().getName()), 1, 3, TimeUnit.SECONDS);
    }
}
复制代码
2020-02-16T18:35:21.598
2020-02-16T18:35:22.606 pool-1-thread-1
2020-02-16T18:35:25.609 pool-1-thread-1
2020-02-16T18:35:26.605 pool-1-thread-2 delay 5s
2020-02-16T18:35:28.614 pool-1-thread-1
2020-02-16T18:35:31.608 pool-1-thread-1
2020-02-16T18:35:34.610 pool-1-thread-1
复制代码
  • 第一种用法即:schedule(Runnable, long, TimeUnit);指定任务的Runnable,延迟多久执行,延迟时间的单位。
  • 第二种用法即:scheduleAtFixedRate(Runnable command,long initialDelay,long period,TimeUnit unit);指定任务的Runnable,初始执行延迟的时间initialDelay,随后每隔period执行一次,并指定时间单位。
  1. workStealingPool
    public static ExecutorService newWorkStealingPool() {
        return new ForkJoinPool
            (Runtime.getRuntime().availableProcessors(),
             ForkJoinPool.defaultForkJoinWorkerThreadFactory,
             null, true);
    }

    public ForkJoinPool(int parallelism,
                        ForkJoinWorkerThreadFactory factory,
                        UncaughtExceptionHandler handler,
                        boolean asyncMode) {
        this(checkParallelism(parallelism),
             checkFactory(factory),
             handler,
             asyncMode ? FIFO_QUEUE : LIFO_QUEUE,
             "ForkJoinPool-" + nextPoolId() + "-worker-");
        checkPermission();
    }
复制代码
  • JDK1.8加入的新线程池,我们可以看到他并不是使用的ThreadPoolExecutor,而是新的线程池类ForkJoinPool,它能够合理的使用CPU进行对任务操作(并行操作),所以适合使用在很耗时的任务中。
  • ForkJoinPool它是一个并行的线程池,参数中传入的是一个线程并发的数量,这里和之前就有很明显的区别,前面4种线程池都有核心线程数、最大线程数等等,而这就使用了一个并发线程数解决问题。这个线程池不会保证任务的顺序执行,也就是 WorkStealing 的意思,抢占式的工作。

通过上面我们了解一一下各个线程的特点。以及内部的参数。使用Executors往往不容易契合我们的业务需求。在阿里的Java代码约定中,明确指出了如下:(取自IDEA提示):

  • 线程池不允许使用Executors去创建,而是通过ThreadPoolExecutor的方式,这样的处理方式让写的同学更加明确线程池的运行规则,规避资源耗尽的风险。 说明:Executors返回的线程池对象的弊端如下: 1)FixedThreadPool和SingleThreadPool:   允许的请求队列长度为Integer.MAX_VALUE,可能会堆积大量的请求,从而导致OOM。 2)CachedThreadPool:   允许的创建线程数量为Integer.MAX_VALUE,可能会创建大量的线程,从而导致OOM。

3.2 使用ThreadPoolExecutor创建线程池

  1. 如果使用ThreadPoolExecutor,我们如何设置线程数是一个问题

    • CPU密集型(加密、计算hash等):最佳线程数为CPU核心数的1-2倍左右
    • 耗时IO型(读写数据库、文件、网络流等):最佳线程数一般大于CPU核心数的很多倍,以JVM线程监控显示繁忙情况为依据,保证线程空闲可以衔接上,参考Brain Goetz推荐的计算方法:
    • 线程数=CPU核心数 * ( 1 + 平均等待时间/平均工作时间 )
    • 更加精准的方式是需要做压测
  2. 使用ThreadPoolExecutor创建线程池的推荐方法(取自阿里Java插件)

    // Positive example 1:
        //org.apache.commons.lang3.concurrent.BasicThreadFactory
        ScheduledExecutorService executorService = 
        new ScheduledThreadPoolExecutor(1,
            new BasicThreadFactory.Builder().namingPattern("example-schedule-pool-%d").daemon(true).build());    
    复制代码
    //Positive example 2:
        ThreadFactory namedThreadFactory = new ThreadFactoryBuilder()
            .setNameFormat("demo-pool-%d").build();
    
        //Common Thread Pool
        ExecutorService pool = new ThreadPoolExecutor(5, 200,
            0L, TimeUnit.MILLISECONDS,
            new LinkedBlockingQueue<Runnable>(1024), namedThreadFactory, new ThreadPoolExecutor.AbortPolicy());
    
        pool.execute(()-> System.out.println(Thread.currentThread().getName()));
        pool.shutdown();//gracefully shutdown
    复制代码
    Positive example 3:
        <bean id="userThreadPool"
    class="org.springframework.scheduling.concurrent.ThreadPoolTaskExecutor">
            <property name="corePoolSize" value="10" />
            <property name="maxPoolSize" value="100" />
            <property name="queueCapacity" value="2000" />
    
        <property name="threadFactory" value= threadFactory />
            <property name="rejectedExecutionHandler">
                <ref local="rejectedExecutionHandler" />
            </property>
        </bean>
        //in code
        userThreadPool.execute(thread);
    复制代码

4. 停止线程池的方法

4.1 shutdown()

  • 这个方法执行了过后,会通知线程池停止,但是不会立即停止,线程池会执行完当前正在执行的任务以及队列里面的任务过后才会停止。
  • 在这个期间,不会接受新的任务,如果提交新任务就会报错

4.2 isShutdown()

  • 如果我们不知道线程是否进入了shutdown(),我们可以通过调用isShutdown()来判断,注意这个isShutdown()是判断是否调用了shutdown()方法,而不是指完全停止了。

4.3 isTerminated()

  • 那我们要判断这个线程池是否完全停止了呢?isTerminated()

4.4 awaitTermination(timeout, TimeUnit);

  • 这个方法用来阻塞等待一个时间后,查看是否完全停止

4.5 案例:

/**
 * @author yiren
 */
public class ThreadPoolShutdown {
    public static void main(String[] args) throws InterruptedException {
        ExecutorService executorService = Executors.newFixedThreadPool(5);
        Runnable runnable = () -> {
            try {
                Thread.sleep(500);
            } catch (InterruptedException e) {
                e.printStackTrace();
            }
            System.out.println(Thread.currentThread().getName());
        };

        for (int i = 0; i < 50; i++) {
            executorService.execute(runnable);
        }
        Thread.sleep(1500);
        executorService.shutdown();
        System.out.println("======> shutdown!");
        try {
            executorService.execute(() -> {
                System.out.println("new Task-1");
            });
        } catch (Exception e) {
            e.printStackTrace();
        }

        boolean isTerminated = executorService.awaitTermination(3, TimeUnit.SECONDS);
        System.out.println("executorService.awaitTermination(3, TimeUnit.SECONDS) = " + isTerminated);
        
        if (executorService.isShutdown()) {
            System.out.println("线程已经进入了关闭阶段,无法提交");
        } else {
            executorService.execute(()->{
                System.out.println("new Task-2");
            });
        }
        Thread.sleep(10000);
        System.out.println("executorService.isTerminated() = " + executorService.isTerminated());
    }
}
复制代码
pool-1-thread-2
......
pool-1-thread-3
======> shutdown!
线程已经进入了关闭阶段,无法提交
pool-1-thread-1
......
pool-1-thread-2
java.util.concurrent.RejectedExecutionException: Task com.imyiren.concurrency.threadpool.ThreadPoolShutdown$$Lambda$2/1072408673@5b480cf9 rejected from java.util.concurrent.ThreadPoolExecutor@6f496d9f[Shutting down, pool size = 5, active threads = 5, queued tasks = 35, completed tasks = 10]
	at java.util.concurrent.ThreadPoolExecutor$AbortPolicy.rejectedExecution(ThreadPoolExecutor.java:2063)
	at java.util.concurrent.ThreadPoolExecutor.reject(ThreadPoolExecutor.java:830)
	at java.util.concurrent.ThreadPoolExecutor.execute(ThreadPoolExecutor.java:1379)
	at com.imyiren.concurrency.threadpool.ThreadPoolShutdown.main(ThreadPoolShutdown.java:28)
pool-1-thread-1
......
pool-1-thread-2
pool-1-thread-3
executorService.isTerminated() = true

复制代码

4.6 shutdownNow()

  • 通过中断信号来停止所有的线程,并发工作队列里面的线程任务以Runnable列表形式返回

  • 案例

/**
 * @author yiren
 */
public class ThreadPoolShutdownNow {
    public static void main(String[] args) throws InterruptedException {
        ExecutorService executorService = Executors.newFixedThreadPool(5);
        Runnable runnable = () -> {
            try {
                Thread.sleep(500);
                System.out.println(Thread.currentThread().getName());
            } catch (InterruptedException e) {
                System.out.println(Thread.currentThread().getName() + " Interrupted");
            }
        };

        for (int i = 0; i < 50; i++) {
            executorService.execute(runnable);
        }
        Thread.sleep(1500);
        List<Runnable> runnableList = executorService.shutdownNow();
        System.out.println("shutdownNow!");
        System.out.println("runnableList.size() = " + runnableList.size());

    }
}
复制代码
pool-1-thread-2
pool-1-thread-5
pool-1-thread-3
pool-1-thread-4
pool-1-thread-1
pool-1-thread-2
pool-1-thread-1
pool-1-thread-4
pool-1-thread-5
pool-1-thread-3
pool-1-thread-1 Interrupted
pool-1-thread-4 Interrupted
pool-1-thread-2 Interrupted
shutdownNow!
pool-1-thread-3 Interrupted
runnableList.size() = 35
pool-1-thread-5 Interrupted

Process finished with exit code 0
复制代码

5. 如何拒绝线程任务

5.1 拒绝时机

  1. 当Executor关闭时,提交新任务会被拒绝
  2. 当Executor的最大线程和工作队列,他们使用有限大小的并且已经达到最大值时

5.2 拒绝策略

  1. AbortPolicy 抛出异常

  2. DiscardPolicy 默默丢弃,你无法得到通知

  3. DiscardOldestPolicy 默默丢弃最老的

  4. CallerRunsPolicy 让提交任务的线程执行

6. 使用周期函数定制线程

6.1 可暂停线程池

/**
 * 演示任务执行前后的周期执行任务
 *
 * @author yiren
 */
public class CanPauseThreadPool extends ThreadPoolExecutor {

    private boolean isPaused;
    private final Lock lock = new ReentrantLock();
    private Condition unPaused = lock.newCondition();

    public CanPauseThreadPool(int corePoolSize, int maximumPoolSize, long keepAliveTime, TimeUnit unit, BlockingQueue<Runnable> workQueue) {
        super(corePoolSize, maximumPoolSize, keepAliveTime, unit, workQueue);
    }

    private void pause() {
        lock.lock();
        try {
            isPaused = true;
        } finally {
            lock.unlock();

        }
    }

    @Override
    protected void beforeExecute(Thread t, Runnable r) {
        super.beforeExecute(t, r);
        lock.lock();
        try {
            while (isPaused) {
                unPaused.await();
            }
        } catch (InterruptedException e) {
            e.printStackTrace();
        }finally {
            lock.unlock();
        }
    }

    public void resume() {
        lock.lock();
        try {
            isPaused = false;
            unPaused.signalAll();
        }finally {
            lock.unlock();
        }
    }

    public static void main(String[] args) throws InterruptedException {
        CanPauseThreadPool canPauseThreadPool = new CanPauseThreadPool(4, 10, 10L, TimeUnit.SECONDS, new ArrayBlockingQueue<Runnable>(1024));
        for (int i = 0; i < 100; i++) {
            canPauseThreadPool.execute(()->{
                try {
                    Thread.sleep(100);
                    System.out.println(Thread.currentThread().getName() + " " + LocalDateTime.now());
                } catch (InterruptedException e) {
                    e.printStackTrace();
                }
            });
        }
        TimeUnit.SECONDS.sleep(1);
        // 开始暂停
        canPauseThreadPool.pause();
        System.out.println("====> 开始暂停 " + LocalDateTime.now());
        TimeUnit.SECONDS.sleep(2);
        System.out.println("====> 恢复线程池 " + LocalDateTime.now());
        canPauseThreadPool.resume();
    }
}
复制代码
pool-1-thread-1 2020-02-16T19:58:56.685
pool-1-thread-2 2020-02-16T19:58:56.685
pool-1-thread-3 2020-02-16T19:58:56.787
pool-1-thread-1 2020-02-16T19:58:56.790
pool-1-thread-2 2020-02-16T19:58:56.790
pool-1-thread-4 2020-02-16T19:58:56.790
pool-1-thread-3 2020-02-16T19:58:56.892
pool-1-thread-1 2020-02-16T19:58:56.894
pool-1-thread-4 2020-02-16T19:58:56.894
pool-1-thread-2 2020-02-16T19:58:56.894
====> 开始暂停 2020-02-16T19:58:56.950
pool-1-thread-3 2020-02-16T19:58:56.996
pool-1-thread-1 2020-02-16T19:58:56.997
pool-1-thread-2 2020-02-16T19:58:56.997
pool-1-thread-4 2020-02-16T19:58:56.997
====> 恢复线程池 2020-02-16T19:58:58.955
pool-1-thread-1 2020-02-16T19:58:59.056
pool-1-thread-3 2020-02-16T19:58:59.056
pool-1-thread-4 2020-02-16T19:58:59.056
pool-1-thread-2 2020-02-16T19:58:59.056
pool-1-thread-1 2020-02-16T19:58:59.157
pool-1-thread-2 2020-02-16T19:58:59.157
pool-1-thread-4 2020-02-16T19:58:59.157

复制代码
  • 由以上案例我们可以知道,我们可以通过重写线程池的周期函数,来在线程池执行任务前停止任务的执行。

6.2 afterExecute

  • 除以上的beforeExecute ,线程池还提供了afterExecute

7. 线程池简单分析

7.1 关系图

我们可以通过IDEA的diagrams工具选中这几个接口和类显示如上关系图。

  • Executor只有一个执行任务的方法

    public interface Executor {
        void execute(Runnable command);
    }
    复制代码
  • ExecutorService 继承自Executor,包含了一些管理方法

    public interface ExecutorService extends Executor {
        void shutdown();
        List<Runnable> shutdownNow();
        boolean isTerminated();
        boolean awaitTermination(long timeout, TimeUnit unit)
            throws InterruptedException;
        <T> Future<T> submit(Callable<T> task);
        <T> Future<T> submit(Runnable task, T result);
        Future<?> submit(Runnable task);
        <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks)
            throws InterruptedException;
        <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks,
                                      long timeout, TimeUnit unit)
            throws InterruptedException;
        <T> T invokeAny(Collection<? extends Callable<T>> tasks)
            throws InterruptedException, ExecutionException;
        <T> T invokeAny(Collection<? extends Callable<T>> tasks,
                        long timeout, TimeUnit unit)
            throws InterruptedException, ExecutionException, TimeoutException;
    }
    复制代码
  • AbstractExecutorServiceThreadPoolExecutor就是具体实现了

  • Executors 则是一个工具类,用来辅助创建线程等。

7.2 一个线程池的组成

主要由以下几个组件组成:

  1. 线程池管理器

  2. 工作线程

  3. 任务队列

  4. 任务接口

7.3 线程池实现任务的复用

  • 首先我们看一下execute(Runnable) 方法

    public void execute(Runnable command) {
        if (command == null)
            throw new NullPointerException();
        
        int c = ctl.get();
       	// 增加核心线程
        if (workerCountOf(c) < corePoolSize) {
            if (addWorker(command, true))
                return;
            c = ctl.get();
        }
        // 添加到队列
        if (isRunning(c) && workQueue.offer(command)) {
            int recheck = ctl.get();
            if (! isRunning(recheck) && remove(command))
                reject(command);
            else if (workerCountOf(recheck) == 0)
                addWorker(null, false);
        }
        // 执行拒绝策略
        else if (!addWorker(command, false))
            reject(command);
    }

复制代码
  • 我们任务进去了过了,线程会封装成一个Worker,线程复用的时候,就是使用固定线程的run方法来不断去判断队列里面是否有任务,有的话就拿出来执行。主要就是Worker里面的runWorker方法:
    final void runWorker(Worker w) {
        Thread wt = Thread.currentThread();
        Runnable task = w.firstTask;
        w.firstTask = null;
        w.unlock(); // allow interrupts
        boolean completedAbruptly = true;
        try {
            while (task != null || (task = getTask()) != null) {
                w.lock();
                // If pool is stopping, ensure thread is interrupted;
                // if not, ensure thread is not interrupted.  This
                // requires a recheck in second case to deal with
                // shutdownNow race while clearing interrupt
                if ((runStateAtLeast(ctl.get(), STOP) ||
                     (Thread.interrupted() &&
                      runStateAtLeast(ctl.get(), STOP))) &&
                    !wt.isInterrupted())
                    wt.interrupt();
                try {
                    beforeExecute(wt, task);
                    Throwable thrown = null;
                    try {
                        task.run();
                    } catch (RuntimeException x) {
                        thrown = x; throw x;
                    } catch (Error x) {
                        thrown = x; throw x;
                    } catch (Throwable x) {
                        thrown = x; throw new Error(x);
                    } finally {
                        afterExecute(task, thrown);
                    }
                } finally {
                    task = null;
                    w.completedTasks++;
                    w.unlock();
                }
            }
            completedAbruptly = false;
        } finally {
            processWorkerExit(w, completedAbruptly);
        }
    }

复制代码
  • 我们可以看到 取出task,然后调用run方法。里面还涵盖了上面的周期函数before和after

8. 线程池状态

  • RUNNING:可以接受新任务并处理排队任务
  • SHUTDOWN:不接受新任务,但是可以处理排队任务
  • STOP:不接受新任务,也不处理排队任务,并且中断正在执行的任务
  • TIDYING:所有线程都已经终止,workerCount为零时,线程会转换到TIDYING状态,并调用terminate()方法
  • TERMINATED:termiante()运行完成

关于我

  • 坐标杭州,普通本科高校计算机科学与技术专业。
  • 20年毕业,主做Java技术栈后端开发。
  • GitHub: github.com/imyiren
  • Blog : imyi.ren

猜你喜欢

转载自juejin.im/post/5e4936cae51d4526d640572d