【手写线程池】Java 语言手写线程池

完成了四种拒绝策略,支持核心线程数常驻,最大线程数超时清扫。
import java.util.LinkedList;
import java.util.Queue;
import java.util.Timer;
import java.util.TimerTask;
import java.util.concurrent.ConcurrentLinkedQueue;

public class ThreadPool {

    public final int cleanInterval = 1000;
    public static final int AbortPolicy = 0;
    public static final int CallerRunsPolicy = 1;
    public static final int DiscardPolicy = 2;
    public static final int DiscardOldestPolicy = 3;

    private final int refusePolicy;

    private final int lifeTime;
    private final int coreLimit;
    private final int maxLimit;
    private int waitLimit;

    private int nowCnt;

    private Timer timer;

    private boolean isRunning;

    private Queue<Task> waitingList = new LinkedList<>();
    private Queue<Thd> freeList = new LinkedList<>();

    public ThreadPool(int coreLimit, int maxLimit, int waitLimit, int lifeTime, int refusePolicy ) {
        this.lifeTime = lifeTime;
        this.coreLimit = coreLimit;
        this.maxLimit = maxLimit;
        this.waitLimit = waitLimit;
        this.refusePolicy = refusePolicy;
        this.isRunning = true;
        setupCleaner();
    }

    public synchronized void close() {
        this.isRunning = false;
    }

    private void setupCleaner() {
        timer = new Timer();
        timer.scheduleAtFixedRate(new TimerTask() {
            @Override
            public void run() {
                clearDeadThread();
            }
        }, cleanInterval, cleanInterval);
    }

    private synchronized void addToPool(Thd thd) {
        freeList.add(thd);
    }

    private synchronized Task getWaitingTask() {
        return waitingList.poll();
    }

    private synchronized Thd getFreeThread() {
        Thd ret = freeList.poll();
        while (ret != null && nowCnt > coreLimit && System.currentTimeMillis() - ret.timeStamp > lifeTime) {
            nowCnt --;
            ret = freeList.poll();
        }
        return ret;
    }

    private synchronized void clearDeadThread() {
        if(nowCnt <= coreLimit) {
            return;
        }
        Queue<Thd> tmp = new LinkedList<>();
        while (!freeList.isEmpty()) {
            Thd thd = getFreeThread();
            if (thd != null) {
                tmp.add(thd);
            }
        }
        freeList.addAll(tmp);
    }

    public boolean submit(Task task) throws Exception {
        boolean accept = true;
        synchronized (this) {
            if (isRunning) {
                Thd thd = getFreeThread();
                if (thd != null) {
                    thd.excuteTask(task);
                } else if (nowCnt < coreLimit) {
                    new Thd(task).start();
                } else if (waitingList.size() < waitLimit) {
                    waitingList.add(task);
                } else if (nowCnt < maxLimit) {
                    new Thd(task).start();
                } else if (refusePolicy == DiscardOldestPolicy) {
                    waitingList.poll();
                    waitingList.add(task);
                } else {
                    accept = false;
                }
            } else {
                accept = false;
            }
        }
        if (!accept) {
            switch (refusePolicy) {
                case AbortPolicy:
                    throw new Exception("submission failed");
                case CallerRunsPolicy:
                    task.work();
                    break;
                case DiscardPolicy:
                    break;
            }
        }
        return accept;
    }

    public interface Task {
        void work() throws InterruptedException;
    }
    private class Thd extends Thread {
        private long timeStamp;

        private Task task;

        public synchronized void excuteTask(Task task) {
            this.task = task;
            this.notify();
        }

        public Thd(Task task) {
            this.task = task;
            nowCnt ++;
        }

        @Override
        public void run() {
            while (true) {
                while (task != null) {
                    try {
                        task.work();
                    } catch (InterruptedException e) {
                        throw new RuntimeException(e);
                    }
                    task = getWaitingTask();
                }
                synchronized (this) {
                    try {
                        timeStamp = System.currentTimeMillis();
                        addToPool(this);
                        wait();
                    } catch (Exception ignored) {
                    }
                }
            }
        }
    }
}

  • 0
    点赞
  • 0
    收藏
    觉得还不错? 一键收藏
  • 1
    评论
手写一个简单的线程池,你可以按照以下步骤进行: 1. 创建一个任务队列,用于存储待执行的任务。 2. 创建一个固定数量的线程池,用于执行任务。 3. 每当有任务提交到线程池时,将任务添加到任务队列中。 4. 线程池中的每个线程会不断从任务队列中获取任务并执行。 5. 执行完一个任务后,线程继续从任务队列中获取下一个任务,并重复执行,直到任务队列为空。 下面是一个简单的 Java 代码示例: ```java import java.util.LinkedList; import java.util.Queue; public class ThreadPool { private final int poolSize; private final WorkerThread[] workerThreads; private final Queue<Runnable> taskQueue; public ThreadPool(int poolSize) { this.poolSize = poolSize; this.taskQueue = new LinkedList<>(); this.workerThreads = new WorkerThread[poolSize]; for (int i = 0; i < poolSize; i++) { workerThreads[i] = new WorkerThread(); workerThreads[i].start(); } } public void submit(Runnable task) { synchronized (taskQueue) { taskQueue.add(task); taskQueue.notify(); // 唤醒等待的线程 } } private class WorkerThread extends Thread { @Override public void run() { while (true) { Runnable task; synchronized (taskQueue) { while (taskQueue.isEmpty()) { try { taskQueue.wait(); // 等待新任务的到来 } catch (InterruptedException e) { Thread.currentThread().interrupt(); return; } } task = taskQueue.poll(); } try { task.run(); // 执行任务 } catch (RuntimeException e) { // 异常处理 } } } } // 使用示例 public static void main(String[] args) { ThreadPool threadPool = new ThreadPool(5); for (int i = 0; i < 10; i++) { final int index = i; threadPool.submit(() -> { System.out.println("Task " + index + " is running."); try { Thread.sleep(1000); } catch (InterruptedException e) { Thread.currentThread().interrupt(); } System.out.println("Task " + index + " is complete."); }); } } } ``` 上述代码中,首先创建了一个任务队列 `taskQueue`,用于存储待执行的任务。然后创建了固定数量的线程池 `workerThreads`,每个线程会不断从任务队列中获取任务并执行。`ThreadPool` 类提供了 `submit` 方法,用于向线程池提交任务。 在 `main` 方法中,我们创建了一个大小为 5 的线程池,并向线程池提交了 10 个任务,每个任务会打印一段文字,并睡眠一秒钟模拟执行任务的耗时。你可以根据实际需求调整线程池的大小和任务的数量。
评论 1
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值