• tomcat线程池


    tomcat线程池和普通的线程池设计上有所区别,下面主要来看看它是如何设计的

    tomcat中线程池的创建 

    org.apache.tomcat.util.net.AbstractEndpoint#createExecutor

    tomcat创建线程池
    public void createExecutor() {
      internalExecutor = true;
      // 任务队列和普通的队列有所区别,后续分析 
      TaskQueue taskqueue = new TaskQueue();
      // 线程工厂用于创建线程  本地项目name=http-nio-port-exec-序号
      TaskThreadFactory tf = new TaskThreadFactory(getName() + "-exec-", daemon, getThreadPriority());
      // 创建线程池,注意这个ThreadPoolExecutor和java.util.concurrent包下的ThreadPoolExecutor有所区别
      executor = new ThreadPoolExecutor(getMinSpareThreads(), getMaxThreads(), 60, TimeUnit.SECONDS,taskqueue, tf);
      // 给任务队列设置线程池,用于后续任务来了判断是创建线程执行还是将线程添加到任务队列
      taskqueue.setParent( (ThreadPoolExecutor) executor);
    }

     

    tomcat的ThreadPoolExecutor

    tomcat的ThreadPoolExecutor实际上继承了java包的ThreadPoolExecutor再其上定制了一些功能

    submittedCount:记录了线程池中正有多少线程在执行任务(还没执行完)

    lastContextStoppedTime:记录上次上下文停止的时间

    lastTimeThreadKilledItself:记录线程上一次为防止内存泄漏自我kill的时间

    构造方法:调用了父类ThreadPoolExecutor,同时调用了prestartAllCoreThreads方法,再完成线程池的创建后预热核心线程,使得任务到来时能够直接执行任务,不用再花时间去创建线程,提高了效率。

    execute方法:执行executor方法时首先将submittedCount加1,再调用父类的executor方法执行任务。若抛出RejectedExecutionException异常则再回尝试将任务添加到任务队列汇中

    afterExecute:重写父类方法,任务执行完成后调用afterExecute钩子方法将submittedCount减1,再尝试停止线程 

    contextStopping:若容器上下文停止,则会记录lastContextStoppedTime为当前时间并中断正在运行的线程。调用currentThreadShouldBeStopped方法的时候会判断线程TaskThread创建的时间是否在lastContextStoppedTime之前,表示当前线程是在上一个上下文运行期间创建,则会尝试kill线程

    public class ThreadPoolExecutor extends java.util.concurrent.ThreadPoolExecutor {
        /**
         * The string manager for this package.
         */
        protected static final StringManager sm = StringManager
                .getManager("org.apache.tomcat.util.threads.res");
    
        /**
         * The number of tasks submitted but not yet finished. This includes tasks
         * in the queue and tasks that have been handed to a worker thread but the
         * latter did not start executing the task yet.
         * This number is always greater or equal to {@link #getActiveCount()}.
         */
        private final AtomicInteger submittedCount = new AtomicInteger(0);
        private final AtomicLong lastContextStoppedTime = new AtomicLong(0L);
    
        /**
         * Most recent time in ms when a thread decided to kill itself to avoid
         * potential memory leaks. Useful to throttle the rate of renewals of
         * threads.
         */
        private final AtomicLong lastTimeThreadKilledItself = new AtomicLong(0L);
    
        /**
         * Delay in ms between 2 threads being renewed. If negative, do not renew threads.
         */
        private long threadRenewalDelay = Constants.DEFAULT_THREAD_RENEWAL_DELAY;
    
        public ThreadPoolExecutor(int corePoolSize, int maximumPoolSize, long keepAliveTime, TimeUnit unit, BlockingQueue workQueue, RejectedExecutionHandler handler) {
            super(corePoolSize, maximumPoolSize, keepAliveTime, unit, workQueue, handler);
            prestartAllCoreThreads();
        }
    
        public ThreadPoolExecutor(int corePoolSize, int maximumPoolSize, long keepAliveTime, TimeUnit unit, BlockingQueue workQueue, ThreadFactory threadFactory,
                RejectedExecutionHandler handler) {
            super(corePoolSize, maximumPoolSize, keepAliveTime, unit, workQueue, threadFactory, handler);
            prestartAllCoreThreads();
        }
    
        public ThreadPoolExecutor(int corePoolSize, int maximumPoolSize, long keepAliveTime, TimeUnit unit, BlockingQueue workQueue, ThreadFactory threadFactory) {
            super(corePoolSize, maximumPoolSize, keepAliveTime, unit, workQueue, threadFactory, new RejectHandler());
            prestartAllCoreThreads();
        }
    
        public ThreadPoolExecutor(int corePoolSize, int maximumPoolSize, long keepAliveTime, TimeUnit unit, BlockingQueue workQueue) {
            super(corePoolSize, maximumPoolSize, keepAliveTime, unit, workQueue, new RejectHandler());
            prestartAllCoreThreads();
        }
    
        public long getThreadRenewalDelay() {
            return threadRenewalDelay;
        }
    
        public void setThreadRenewalDelay(long threadRenewalDelay) {
            this.threadRenewalDelay = threadRenewalDelay;
        }
    
        @Override
        protected void afterExecute(Runnable r, Throwable t) {
            submittedCount.decrementAndGet();
    
            if (t == null) {
                stopCurrentThreadIfNeeded();
            }
        }
    
        /**
         * If the current thread was started before the last time when a context was
         * stopped, an exception is thrown so that the current thread is stopped.
         */
        protected void stopCurrentThreadIfNeeded() {
            if (currentThreadShouldBeStopped()) {
                long lastTime = lastTimeThreadKilledItself.longValue();
                if (lastTime + threadRenewalDelay < System.currentTimeMillis()) {
                    if (lastTimeThreadKilledItself.compareAndSet(lastTime,
                            System.currentTimeMillis() + 1)) {
                        // OK, it's really time to dispose of this thread
    
                        final String msg = sm.getString(
                                        "threadPoolExecutor.threadStoppedToAvoidPotentialLeak",
                                        Thread.currentThread().getName());
    
                        throw new StopPooledThreadException(msg);
                    }
                }
            }
        }
    
        protected boolean currentThreadShouldBeStopped() {
            if (threadRenewalDelay >= 0
                && Thread.currentThread() instanceof TaskThread) {
                TaskThread currentTaskThread = (TaskThread) Thread.currentThread();
                if (currentTaskThread.getCreationTime() <
                        this.lastContextStoppedTime.longValue()) {
                    return true;
                }
            }
            return false;
        }
    
        public int getSubmittedCount() {
            return submittedCount.get();
        }
    
        /**
         * {@inheritDoc}
         */
        @Override
        public void execute(Runnable command) {
            execute(command,0,TimeUnit.MILLISECONDS);
        }
    
        /**
         * Executes the given command at some time in the future.  The command
         * may execute in a new thread, in a pooled thread, or in the calling
         * thread, at the discretion of the Executor implementation.
         * If no threads are available, it will be added to the work queue.
         * If the work queue is full, the system will wait for the specified
         * time and it throw a RejectedExecutionException if the queue is still
         * full after that.
         *
         * @param command the runnable task
         * @param timeout A timeout for the completion of the task
         * @param unit The timeout time unit
         * @throws RejectedExecutionException if this task cannot be
         * accepted for execution - the queue is full
         * @throws NullPointerException if command or unit is null
         */
        public void execute(Runnable command, long timeout, TimeUnit unit) {
            submittedCount.incrementAndGet();
            try {
                super.execute(command);
            } catch (RejectedExecutionException rx) {
                if (super.getQueue() instanceof TaskQueue) {
                    final TaskQueue queue = (TaskQueue)super.getQueue();
                    try {
                        if (!queue.force(command, timeout, unit)) {
                            submittedCount.decrementAndGet();
                            throw new RejectedExecutionException("Queue capacity is full.");
                        }
                    } catch (InterruptedException x) {
                        submittedCount.decrementAndGet();
                        throw new RejectedExecutionException(x);
                    }
                } else {
                    submittedCount.decrementAndGet();
                    throw rx;
                }
    
            }
        }
    
        public void contextStopping() {
            this.lastContextStoppedTime.set(System.currentTimeMillis());
    
            // save the current pool parameters to restore them later
            int savedCorePoolSize = this.getCorePoolSize();
            TaskQueue taskQueue =
                    getQueue() instanceof TaskQueue ? (TaskQueue) getQueue() : null;
            if (taskQueue != null) {
                // note by slaurent : quite oddly threadPoolExecutor.setCorePoolSize
                // checks that queue.remainingCapacity()==0. I did not understand
                // why, but to get the intended effect of waking up idle threads, I
                // temporarily fake this condition.
                taskQueue.setForcedRemainingCapacity(Integer.valueOf(0));
            }
    
            // setCorePoolSize(0) wakes idle threads
            this.setCorePoolSize(0);
    
            // TaskQueue.take() takes care of timing out, so that we are sure that
            // all threads of the pool are renewed in a limited time, something like
            // (threadKeepAlive + longest request time)
    
            if (taskQueue != null) {
                // ok, restore the state of the queue and pool
                taskQueue.setForcedRemainingCapacity(null);
            }
            this.setCorePoolSize(savedCorePoolSize);
        }
    
        private static class RejectHandler implements RejectedExecutionHandler {
            @Override
            public void rejectedExecution(Runnable r,
                    java.util.concurrent.ThreadPoolExecutor executor) {
                throw new RejectedExecutionException();
            }
    
        }
    
    
    }

     

    tomcat的TaskQueue

    首先简单翻一下注释,为线程池运行专门设计的队列,使用该队列线程池如果有空闲队列则会创建线程池执行任务而不是将任务放到任务队列中。

    它继承了LinkedBlockingQueue无界队列,容量为Integer.MAX_VALUE。

    在execute方法中可以看到,当线程池线程大于核心数量的时候,会执行任务队列的offer方法,下来来分析下TaskQueue的offer方法:

    1.若parent为空也就是未给队列设置线程池,则调用父类offer方法,将任务添加到队列中

    2.线程池当前线程数量等于线程池最大数量,无法添加更多的线程,调用父类offer方法,将任务添加到队列中

    3.线程池正在执行任务的线程数量小于等于线程池已有的线程数量,说明当前线程池有空闲线程,调用父类offer方法,将任务添加到队列中,等待线程从队列中取任务运行

    4.线程池线程数量小于线程池最大数量说明还可以增加线程,返回false,运行addWorker(command,false)向线程池添加非核心线程运行任务 

    5.都不满足,调用父类offer方法,将任务添加到队列中 

    从上面的分析我们可以看到该任务队列TaskQueue和普通的任务队列不一样,当线程池的线程数量小于最大线程数量时,任务不会添加到任务队列中,而是会添加非核心线程来运行任务,当线程池线程数量达到最大数量时,才会将任务添加到任务队列中 

    当然TaskQueue也有force方法直接调用父类offer方法将任务添加到任务队列中 

    /**
     * As task queue specifically designed to run with a thread pool executor. The
     * task queue is optimised to properly utilize threads within a thread pool
     * executor. If you use a normal queue, the executor will spawn threads when
     * there are idle threads and you wont be able to force items onto the queue
     * itself.
     */
    public class TaskQueue extends LinkedBlockingQueue {
    
        private static final long serialVersionUID = 1L;
    
        private transient volatile ThreadPoolExecutor parent = null;
    
        // No need to be volatile. This is written and read in a single thread
        // (when stopping a context and firing the  listeners)
        private Integer forcedRemainingCapacity = null;
    
        public TaskQueue() {
            super();
        }
    
        public TaskQueue(int capacity) {
            super(capacity);
        }
    
        public TaskQueue(Collection c) {
            super(c);
        }
    
        public void setParent(ThreadPoolExecutor tp) {
            parent = tp;
        }
    
        public boolean force(Runnable o) {
            if (parent == null || parent.isShutdown()) throw new RejectedExecutionException("Executor not running, can't force a command into the queue");
            return super.offer(o); //forces the item onto the queue, to be used if the task is rejected
        }
    
        public boolean force(Runnable o, long timeout, TimeUnit unit) throws InterruptedException {
            if (parent == null || parent.isShutdown()) throw new RejectedExecutionException("Executor not running, can't force a command into the queue");
            return super.offer(o,timeout,unit); //forces the item onto the queue, to be used if the task is rejected
        }
    
        @Override
        public boolean offer(Runnable o) {
          //we can't do any checks
            if (parent==null) return super.offer(o);
            //we are maxed out on threads, simply queue the object
            if (parent.getPoolSize() == parent.getMaximumPoolSize()) return super.offer(o);
            //we have idle threads, just add it to the queue
            if (parent.getSubmittedCount()<=(parent.getPoolSize())) return super.offer(o);
            //if we have less threads than maximum force creation of a new thread
            if (parent.getPoolSize()return false;
            //if we reached here, we need to add it to the queue
            return super.offer(o);
        }
    
    
        @Override
        public Runnable poll(long timeout, TimeUnit unit)
                throws InterruptedException {
            Runnable runnable = super.poll(timeout, unit);
            if (runnable == null && parent != null) {
                // the poll timed out, it gives an opportunity to stop the current
                // thread if needed to avoid memory leaks.
                parent.stopCurrentThreadIfNeeded();
            }
            return runnable;
        }
    
        @Override
        public Runnable take() throws InterruptedException {
            if (parent != null && parent.currentThreadShouldBeStopped()) {
                return poll(parent.getKeepAliveTime(TimeUnit.MILLISECONDS),
                        TimeUnit.MILLISECONDS);
                // yes, this may return null (in case of timeout) which normally
                // does not occur with take()
                // but the ThreadPoolExecutor implementation allows this
            }
            return super.take();
        }
    
        @Override
        public int remainingCapacity() {
            if (forcedRemainingCapacity != null) {
                // ThreadPoolExecutor.setCorePoolSize checks that
                // remainingCapacity==0 to allow to interrupt idle threads
                // I don't see why, but this hack allows to conform to this
                // "requirement"
                return forcedRemainingCapacity.intValue();
            }
            return super.remainingCapacity();
        }
    
        public void setForcedRemainingCapacity(Integer forcedRemainingCapacity) {
            this.forcedRemainingCapacity = forcedRemainingCapacity;
        }
    
    }

     

    当有请求来时,从socket获取到可读事件并将socket封装成一个任务(任务主要是解析请求然后下发到servlet执行),然后调用线程池的execute方法

        /**
         * Process the given SocketWrapper with the given status. Used to trigger
         * processing as if the Poller (for those endpoints that have one)
         * selected the socket.
         *
         * @param socketWrapper The socket wrapper to process
         * @param event         The socket event to be processed
         * @param dispatch      Should the processing be performed on a new
         *                          container thread
         *
         * @return if processing was triggered successfully
         */
        public boolean processSocket(SocketWrapperBase socketWrapper,
                SocketEvent event, boolean dispatch) {
            try {
                if (socketWrapper == null) {
                    return false;
                }
                SocketProcessorBase sc = processorCache.pop();
                if (sc == null) {
                    sc = createSocketProcessor(socketWrapper, event);
                } else {
                    sc.reset(socketWrapper, event);
                }
                Executor executor = getExecutor();
                if (dispatch && executor != null) {
                    executor.execute(sc);
                } else {
                    sc.run();
                }
            } catch (RejectedExecutionException ree) {
                getLog().warn(sm.getString("endpoint.executor.fail", socketWrapper) , ree);
                return false;
            } catch (Throwable t) {
                ExceptionUtils.handleThrowable(t);
                // This means we got an OOM or similar creating a thread, or that
                // the pool and its queue are full
                getLog().error(sm.getString("endpoint.process.fail"), t);
                return false;
            }
            return true;
        }

     

  • 相关阅读:
    Kubernetes学习笔记-保障集群内节点和网络安全(4)隔离pod的网络20220911
    计算机毕业设计之java+springboot基于vue的地方美食分享网站
    HarmonyOS开发案例:【图片编辑】
    ssm毕设项目学生兼职信息管理系统66n7e(java+VUE+Mybatis+Maven+Mysql+sprnig)
    三维量子成像雷达
    【SA8295P 源码分析 (三)】127 - 摄像头 GMSL1、GMSL2 加串-解串器 常用寄存器配置整理
    Api 接口优化的那些技巧
    VectorCAST测试工具环境搭建
    Navicat导入Excel数据顺序变了
    面试官居然问我:删库后,除了跑路还能干什么?
  • 原文地址:https://www.cnblogs.com/monianxd/p/16579339.html