美文网首页
Java8线程池理解(二)

Java8线程池理解(二)

作者: 多喝水JS | 来源:发表于2017-09-11 18:00 被阅读65次

    addWorker(Runnable firstTask, boolean core)方法

    /**
         * Checks if a new worker can be added with respect to current
         * pool state and the given bound (either core or maximum). If so,
         * the worker count is adjusted accordingly, and, if possible, a
         * new worker is created and started, running firstTask as its
         * first task. This method returns false if the pool is stopped or
         * eligible to shut down. It also returns false if the thread
         * factory fails to create a thread when asked.  If the thread
         * creation fails, either due to the thread factory returning
         * null, or due to an exception (typically OutOfMemoryError in
         * Thread.start()), we roll back cleanly.
         *
         * @param firstTask the task the new thread should run first (or
         * null if none). Workers are created with an initial first task
         * (in method execute()) to bypass queuing when there are fewer
         * than corePoolSize threads (in which case we always start one),
         * or when the queue is full (in which case we must bypass queue).
         * Initially idle threads are usually created via
         * prestartCoreThread or to replace other dying workers.
         *
         * @param core if true use corePoolSize as bound, else
         * maximumPoolSize. (A boolean indicator is used here rather than a
         * value to ensure reads of fresh values after checking other pool
         * state).
         * @return true if successful
         */
        private boolean addWorker(Runnable firstTask, boolean core) {
            retry:
            for (;;) {
                int c = ctl.get();
                int rs = runStateOf(c);
    
                // Check if queue empty only if necessary.
                if (rs >= SHUTDOWN &&
                    ! (rs == SHUTDOWN &&
                       firstTask == null &&
                       ! workQueue.isEmpty()))
                    return false;
    
                for (;;) {
                    int wc = workerCountOf(c);
                    if (wc >= CAPACITY ||
                        wc >= (core ? corePoolSize : maximumPoolSize))
                        return false;
                    if (compareAndIncrementWorkerCount(c))
                        break retry;
                    c = ctl.get();  // Re-read ctl
                    if (runStateOf(c) != rs)
                        continue retry;
                    // else CAS failed due to workerCount change; retry inner loop
                }
            }
    
            boolean workerStarted = false;
            boolean workerAdded = false;
            Worker w = null;
            try {
                w = new Worker(firstTask);
                final Thread t = w.thread;
                if (t != null) {
                    final ReentrantLock mainLock = this.mainLock;
                    mainLock.lock();
                    try {
                        // Recheck while holding lock.
                        // Back out on ThreadFactory failure or if
                        // shut down before lock acquired.
                        int rs = runStateOf(ctl.get());
    
                        if (rs < SHUTDOWN ||
                            (rs == SHUTDOWN && firstTask == null)) {
                            if (t.isAlive()) // precheck that t is startable
                                throw new IllegalThreadStateException();
                            workers.add(w);
                            int s = workers.size();
                            if (s > largestPoolSize)
                                largestPoolSize = s;
                            workerAdded = true;
                        }
                    } finally {
                        mainLock.unlock();
                    }
                    if (workerAdded) {
                        t.start();
                        workerStarted = true;
                    }
                }
            } finally {
                if (! workerStarted)
                    addWorkerFailed(w);
            }
            return workerStarted;
        }
    

    执行流程
    ①首先两个for循环,先来看外面的for循环

    int c = ctl.get();
    int rs = runStateOf(c);
    
    // Check if queue empty only if necessary.
    if (rs >= SHUTDOWN && ! (rs == SHUTDOWN && firstTask == null &&
              ! workQueue.isEmpty()))
            return false;
    

    1、首先获取当前线程池的运行状态。进入2
    2、先来回顾一个线程池的几种状态:

        private static final int RUNNING    = -1 << COUNT_BITS;
        private static final int SHUTDOWN   =  0 << COUNT_BITS;
        private static final int STOP       =  1 << COUNT_BITS;
        private static final int TIDYING    =  2 << COUNT_BITS;
        private static final int TERMINATED =  3 << COUNT_BITS;
    

    if语句里主要判断如果当前线程池已经被关闭了或者线程池被关闭了,缓存队列还有任务,那直接返回false,结束流程。这里只要是判断线程池是否已经被关闭了,如果已经被关闭了,那么就不再接受任务了。

    ③如果线程池还没被关闭,那么进入第二for循环

    for (;;) {
          int wc = workerCountOf(c);
          if (wc >= CAPACITY || wc >= (core ? corePoolSize : maximumPoolSize))
                  return false;
         if (compareAndIncrementWorkerCount(c))
                 break retry;
          c = ctl.get();  // Re-read ctl
          if (runStateOf(c) != rs)
                 continue retry;
           // else CAS failed due to workerCount change; retry inner loop
    }
    

    1、首先获取到当前线程池的线程数

     int wc = workerCountOf(c);
    

    2、判断线程数有没有>= corePoolSize : maximumPoolSize,成立的话,直接退出循环,返回false。下面的core是boolean值

     if (wc >= CAPACITY || wc >= (core ? corePoolSize : maximumPoolSize))
                  return false;
    

    3、然后更新线程池的线程数

      if (compareAndIncrementWorkerCount(c))
                        break retry;
    

    更新不成功,则结束本循环
    4、再次判断线程池的运行状态

     c = ctl.get();  // Re-read ctl
      if (runStateOf(c) != rs)
            continue retry;
    

    如果不相等,说明线程池的状态已经被其他线程改变了,直接结束此次循环

    上面的两个循环只要是判断线程池的状态,然后更新线程池的线程数
    接下来的流程就是把任务添加到任务队列中,并交给线程池中空闲的线程来执行

           boolean workerStarted = false;
            boolean workerAdded = false;
            Worker w = null;
            try {
                w = new Worker(firstTask);
                final Thread t = w.thread;
                if (t != null) {
                    final ReentrantLock mainLock = this.mainLock;
                    mainLock.lock();
                    try {
                        // Recheck while holding lock.
                        // Back out on ThreadFactory failure or if
                        // shut down before lock acquired.
                        int rs = runStateOf(ctl.get());
    
                        if (rs < SHUTDOWN ||
                            (rs == SHUTDOWN && firstTask == null)) {
                            if (t.isAlive()) // precheck that t is startable
                                throw new IllegalThreadStateException();
                            workers.add(w);
                            int s = workers.size();
                            if (s > largestPoolSize)
                                largestPoolSize = s;
                            workerAdded = true;
                        }
                    } finally {
                        mainLock.unlock();
                    }
                    if (workerAdded) {
                        t.start();
                        workerStarted = true;
                    }
                }
            } finally {
                if (! workerStarted)
                    addWorkerFailed(w);
            }
    

    5、首先创建一个worker工作队列对象

     Worker(Runnable firstTask) {
                setState(-1); // inhibit interrupts until runWorker
                this.firstTask = firstTask;
                this.thread = getThreadFactory().newThread(this);
     }
    

    可以看出,这个对象保存提交的任务,并把创建一个工作线程来执行这个提交的任务
    6、首先加锁,然后判断线程池状态,如果处于运行时状态,就把刚才创建的worker工作队列添加到worker工作队列中,然后启动工作线程执行任务

     if (t != null) {
           final ReentrantLock mainLock = this.mainLock;
            mainLock.lock();
            try {
               // Recheck while holding lock.
               // Back out on ThreadFactory failure or if
                // shut down before lock acquired.
                int rs = runStateOf(ctl.get());
    
                if (rs < SHUTDOWN || (rs == SHUTDOWN && firstTask == null)) {
                      if (t.isAlive()) // precheck that t is startable
                           throw new IllegalThreadStateException();
                     workers.add(w);
                     int s = workers.size();
                     if (s > largestPoolSize)
                          largestPoolSize = s;
                         workerAdded = true;
                     }
           } finally {
                   mainLock.unlock();
    }
    

    Worker

    线程池中的每一个线程被封装成一个Worker对象,ThreadPool维护的其实就是一组Worker对象,看一下Worker的定义:

     private final class Worker extends AbstractQueuedSynchronizer implements Runnable
    

    可以看到worker本身就是一个线程,所以看它的run()方法

     public void run() {
                runWorker(this);
      }
    

    最终调用了 runWorker(this)方法

        /**
         * Main worker run loop.  Repeatedly gets tasks from queue and
         * executes them, while coping with a number of issues:
         *
         * 1. We may start out with an initial task, in which case we
         * don't need to get the first one. Otherwise, as long as pool is
         * running, we get tasks from getTask. If it returns null then the
         * worker exits due to changed pool state or configuration
         * parameters.  Other exits result from exception throws in
         * external code, in which case completedAbruptly holds, which
         * usually leads processWorkerExit to replace this thread.
         *
         * 2. Before running any task, the lock is acquired to prevent
         * other pool interrupts while the task is executing, and then we
         * ensure that unless pool is stopping, this thread does not have
         * its interrupt set.
         *
         * 3. Each task run is preceded by a call to beforeExecute, which
         * might throw an exception, in which case we cause thread to die
         * (breaking loop with completedAbruptly true) without processing
         * the task.
         *
         * 4. Assuming beforeExecute completes normally, we run the task,
         * gathering any of its thrown exceptions to send to afterExecute.
         * We separately handle RuntimeException, Error (both of which the
         * specs guarantee that we trap) and arbitrary Throwables.
         * Because we cannot rethrow Throwables within Runnable.run, we
         * wrap them within Errors on the way out (to the thread's
         * UncaughtExceptionHandler).  Any thrown exception also
         * conservatively causes thread to die.
         *
         * 5. After task.run completes, we call afterExecute, which may
         * also throw an exception, which will also cause thread to
         * die. According to JLS Sec 14.20, this exception is the one that
         * will be in effect even if task.run throws.
         *
         * The net effect of the exception mechanics is that afterExecute
         * and the thread's UncaughtExceptionHandler have as accurate
         * information as we can provide about any problems encountered by
         * user code.
         *
         * @param w the worker
         */
        final void runWorker(Worker w) {
           Thread wt = Thread.currentThread();
             // 获取第一个任务
            Runnable task = w.firstTask;
            w.firstTask = null;
              // 允许中断
            w.unlock(); // allow interrupts
            // 是否因为异常退出循环
            boolean completedAbruptly = true;
            try {
                // 如果task为空,则通过getTask来获取任务
                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);
            }
        }
    

    执行流程
    ①while循环不断地通过getTask()方法获取任务;
    ②getTask()方法从阻塞队列中取任务;
    ③如果线程池正在停止,那么要保证当前线程是中断状态,否则要保证当前线程不是中断状态;
    ④调用task.run()执行任务;
    ⑤如果task为null则跳出循环,执行processWorkerExit()方法;
    ⑥runWorker方法执行完毕,也代表着Worker中的run方法执行完毕,销毁线程。

    相关文章

      网友评论

          本文标题:Java8线程池理解(二)

          本文链接:https://www.haomeiwen.com/subject/ripfsxtx.html