美文网首页面试
并发总结(中)

并发总结(中)

作者: 想54256 | 来源:发表于2020-03-26 16:17 被阅读0次

    六、共享模型 —— 不可变

    不可变对象是多个线程安全的,因为没有人能够改变其内部状态

    引子:日期转换的问题

    下面的代码在运行时,由于 SimpleDateFormat 不是线程安全的。

    @Slf4j(topic = "c.Test1")
    public class Test1 {
        public static void main(String[] args) {
            test();
        }
    
        private static void test() {
            SimpleDateFormat sdf = new SimpleDateFormat("yyyy-MM-dd");
            for (int i = 0; i < 10; i++) {
                new Thread(() -> {
                    synchronized (sdf) {
                        try {
                            log.debug("{}", sdf.parse("1951-04-21"));
                        } catch (Exception e) {
                            log.error("{}", e);
                        }
                    }
                }).start();
            }
        }
    }
    

    有很大几率出现 java.lang.NumberFormatException 或者出现不正确的日期解析结果。

    解决思路:如果一个对象在不能够修改其内部状态(属性),那么它就是线程安全的,因为不存在并发修改啊!这样的对象在Java 中有很多,例如在 Java 8 后,提供了一个新的日期格式化类:

    DateTimeFormatter stf = DateTimeFormatter.ofPattern("yyyy-MM-dd");
    for (int i = 0; i < 10; i++) {
        new Thread(() -> {
            TemporalAccessor parse = stf.parse("1951-04-21");
            log.debug("{}", parse);
        }).start();
    }
    

    不可变对象,实际是另一种避免竞争的方式。

    不可变设计

    String 类也是不可变的,以它为例,说明一下不可变设计的要素

    public final class String
                implements java.io.Serializable, Comparable<String>, CharSequence {
        /**
         * The value is used for character storage.
         */
        private final char value[];
        /**
         * Cache the hash code for the string
         */
        private int hash; // Default to 0
        // ...
    }
    

    发现该类、类中所有属性都是 final 的

    • 属性用 final 修饰保证了该属性是只读的,不能修改
    • 类用 final 修饰保证了该类中的方法不能被覆盖,防止子类无意间破坏不可变性

    保护性拷贝

    public String(char value[]) {
        this.value = Arrays.copyOf(value, value.length);
    }
    

    构造新字符串对象时,会生成新的 char[] value,对内容进行复制。这种通过创建副本对象来避免共享的手段称之为【保护性拷贝(defensive copy)】

    final 的原理

    设置 final 变量的原理

    理解了 volatile 原理,再对比 final 的实现就比较简单了

    public class TestFinal { 
        final int a = 20;
    }
    
    0: aload_0
    1: invokespecial #1 
    4: aload_0
    5: bipush 20 
    7: putfield #2
    <-- 写屏障 
    10: return
    

    发现 final 变量的赋值也会通过 putfield 指令来完成,同样在这条指令之后也会加入写屏障,保证在其它线程读到它的值时不会出现为 0 的情况

    获取 final 变量的原理

    如果是基本类型或String类型会将其编译进字节码中。

    ?final修饰的可以被反射修改吗

    https://www.jianshu.com/p/2d490b0155ad

    无状态

    在 web 阶段学习时,设计 Servlet 时为了保证其线程安全,都会有这样的建议,不要为 Servlet 设置成员变量,这种没有任何成员变量的类是线程安全的

    因为成员变量保存的数据也可以称为状态信息,因此没有成员变量就称之为【无状态】

    七、共享模型 —— 工具

    7.1 引子:自定义线程池

    @Slf4j
    public class TestPool {
        public static void main(String[] args) {
            ThreadPool threadPool = new ThreadPool(1, 1,
                    1000, TimeUnit.MILLISECONDS, (queue, task) -> {
                // 1. 死等
    //            queue.put(task);
                // 2) 带超时等待
    //            queue.offer(task, 1500, TimeUnit.MILLISECONDS);
                // 3) 让调用者放弃任务执行
    //            log.debug("放弃{}", task);
                // 4) 让调用者抛出异常
    //            throw new RuntimeException("任务执行失败 " + task);
                // 5) 让调用者自己执行任务
                task.run();
            });
            for (int i = 0; i < 4; i++) {
                int j = i;
                threadPool.execute(() -> {
                    try {
                        Thread.sleep(1000L);
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                    log.debug("{}", j);
                });
            }
        }
    }
    
    // 拒绝策略
    @FunctionalInterface
    interface RejectPolicy<T> {
        void reject(BQ<T> queue, T task);
    }
    
    @Slf4j
    class ThreadPool {
    
        // 任务队列
        private BQ<Runnable> taskQueue;
    
        // 线程集合
        private final HashSet<Worker> workers = new HashSet<>();
    
        // 核心线程数
        private int coreSize;
    
        // 获取任务时的超时时间
        private long timeout;
    
        // 超时时间单位
        private TimeUnit timeUnit;
    
        // 拒绝策略
        private RejectPolicy<Runnable> rejectPolicy;
    
        // 执行任务
        public void execute(Runnable task) {
            synchronized (workers) {
                // 当任务数没有超过 coreSize 时,直接交给 worker 对象执行
                if (workers.size() < coreSize) {
                    Worker worker = new Worker(task);
                    log.debug("新增 worker{}, {}", worker, task);
                    worker.start();
                    workers.add(worker);
                    return;
                }
            }
            // 如果任务数超过 coreSize 时,加入任务队列暂存
            taskQueue.tryPut(rejectPolicy, task);
        }
    
        public ThreadPool(int taskQueueCapacity, int coreSize, long timeout, TimeUnit timeUnit, RejectPolicy<Runnable> rejectPolicy) {
            this.taskQueue = new BQ<>(taskQueueCapacity);
            this.coreSize = coreSize;
            this.timeout = timeout;
            this.timeUnit = timeUnit;
            this.rejectPolicy = rejectPolicy;
        }
    
        class Worker extends Thread {
    
            private Runnable task;
    
            @Override
            public void run() {
                // 1) 当 task 不为空,执行任务
                // 2) 当 task 执行完毕,再接着从任务队列获取任务并执行
                while (task != null || (task = taskQueue.poll(timeout, timeUnit)) != null) {
                    try {
                        log.debug("正在执行...{}", task);
                        task.run();
                    } finally {
                        task = null;
                    }
                }
                synchronized (workers) {
                    log.debug("worker 被移除{}", this);
                    workers.remove(this);
                }
            }
    
            public Worker(Runnable task) {
                super(task);
                this.task = task;
            }
        }
    }
    
    
    @Slf4j
    class BQ<T> {
    
        // 任务队列
        private Deque<T> queue;
    
        // 锁
        private ReentrantLock lock = new ReentrantLock();
    
        // 生产者条件变量
        private Condition fullWaitCondition = lock.newCondition();
    
        // 消费者条件变量
        private Condition emptyWaitCondition = lock.newCondition();
    
        // 容量
        private int capacity;
    
        public BQ(int capacity) {
            this.capacity = capacity;
            this.queue = new ArrayDeque<>(capacity);
        }
    
        // 阻塞添加
        public void put(T task) {
            try {
                lock.lock();
                while (queue.size() == capacity) {
                    log.debug("等待加入任务队列 {} ...", task);
                    try {
                        fullWaitCondition.await();
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                }
    
                log.debug("加入任务队列 {}", task);
                queue.addLast(task);
                emptyWaitCondition.signal();
            } finally {
                lock.unlock();
            }
        }
    
        // 带超时时间阻塞添加
        public boolean offer(T task, long timeout, TimeUnit timeUnit) {
            try {
                lock.lock();
                long nanos = timeUnit.toNanos(timeout);
                while (queue.size() == capacity) {
    
                    try {
                        if (nanos <= 0) {
                            return false;
                        }
                        // 返回值是剩余时间
                        nanos = fullWaitCondition.awaitNanos(nanos);
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                }
    
                log.debug("加入任务队列 {}", task);
                queue.addLast(task);
                emptyWaitCondition.signal();
                return true;
            } finally {
                lock.unlock();
            }
        }
    
        public void tryPut(RejectPolicy<T> rejectPolicy, T task) {
            lock.lock();
            try {
                // 判断队列是否满
                if (queue.size() == capacity) {
                    rejectPolicy.reject(this, task);
                } else {  // 有空闲
                    log.debug("加入任务队列 {}", task);
                    queue.addLast(task);
                    emptyWaitCondition.signal();
                }
            } finally {
                lock.unlock();
            }
        }
    
        // 阻塞获取
        public T take() {
            try {
                lock.lock();
                while (queue.isEmpty()) {
                    try {
                        emptyWaitCondition.await();
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                }
                T task = queue.removeFirst();
                fullWaitCondition.signal();
                return task;
            } finally {
                lock.unlock();
            }
        }
    
        // 带超时阻塞获取
        public T poll(long timeout, TimeUnit unit) {
            try {
                lock.lock();
                long nanos = unit.toNanos(timeout);
    
                while (queue.isEmpty()) {
                    try {
                        if (nanos <= 0) {
                            return null;
                        }
    
                        // 返回值是剩余时间
                        nanos = emptyWaitCondition.awaitNanos(nanos);
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                }
    
                T task = queue.removeFirst();
                fullWaitCondition.signal();
                return task;
            } finally {
                lock.unlock();
            }
        }
    
        public int size() {
            lock.lock();
            try {
                return queue.size();
            } finally {
                lock.unlock();
            }
        }
    
    }
    

    7.2 线程池

    继承体系

    7.2.1 线程池状态

    ThreadPoolExecutor 使用 int 的高 3 位来表示线程池状态,低 29 位表示线程数量。

    image

    从数字上比较,TERMINATED > TIDYING > STOP > SHUTDOWN > RUNNING

    它将线程池状态和线程数量存储在一个原子变量 ctl 中,目的是将线程池状态与线程个数合二为一,这样就可以用一次 cas 原子操作进行赋值。(为了省时)

    // c 为旧值, ctlOf 返回结果为新值
    ctl.compareAndSet(c, ctlOf(targetState, workerCountOf(c))));
    // rs 为高 3 位代表线程池状态, wc 为低 29 位代表线程个数,ctl 是合并它们 
    private static int ctlOf(int rs, int wc) { return rs | wc; }
    

    7.2.2 构造方法

    public ThreadPoolExecutor(int corePoolSize,
                              int maximumPoolSize,
                              long keepAliveTime,
                              TimeUnit unit,
                              BlockingQueue<Runnable> workQueue,
                              ThreadFactory threadFactory,
                              RejectedExecutionHandler handler) {
    
    • corePoolSize 核心线程数目 (最多保留的线程数)
    • maximumPoolSize 最大线程数目 (救急线程 = 总线程数 - 核心线程数)
    • keepAliveTime 生存时间(针对救急线程)
    • unit 时间单位(针对救急线程)
    • workQueue 阻塞队列
    • threadFactory 线程工厂(可以为线程创建时起个好名字)
    • handler 拒绝策略
    工作方式
    1. 线程池中刚开始没有线程,当一个任务提交给线程池后,线程池会创建一个新线程来执行任务。
    2. 当线程数达到 corePoolSize 并没有线程空闲,这时再加入任务,新加的任务会被加入workQueue 队列排队,直到有空闲的线程。
    3. 如果队列选择了有界队列,那么任务超过了队列大小时,会创建 maximumPoolSize - corePoolSize 数目的线程来救急。
    4. 如果线程到达 maximumPoolSize 仍然有新任务这时会执行拒绝策略。拒绝策略 jdk 提供了 4 种实现,其它著名框架也提供了实现
    • AbortPolicy 让调用者抛出 RejectedExecutionException 异常,这是默认策略
    • CallerRunsPolicy 让调用者运行任务
    • DiscardPolicy 放弃本次任务
    • DiscardOldestPolicy 放弃队列中最早的任务,本任务取而代之
    • Dubbo 的实现,在抛出 RejectedExecutionException 异常之前会记录日志,并 dump 线程栈信息,方便定位问题
    • Netty 的实现,是创建一个新线程来执行任务
    • ActiveMQ 的实现,带超时等待(60s)尝试放入队列,类似我们之前自定义的拒绝策略
    • PinPoint 的实现,它使用了一个拒绝策略链,会逐一尝试策略链中每种拒绝策略


      image
    1. 当高峰过去后,超过corePoolSize 的救急线程如果一段时间没有任务做,需要结束节省资源,这个时间由 keepAliveTime 和 unit 来控制。

    7.2.3 Executors 类

    根据这个构造方法,JDK Executors 类中提供了众多工厂方法来创建各种用途的线程池。

    newFixedThreadPool

    public static ExecutorService newFixedThreadPool(int nThreads) {
        return new ThreadPoolExecutor(nThreads, nThreads,
                                        0L, TimeUnit.MILLISECONDS,
                                        new LinkedBlockingQueue<Runnable>());
    }
    

    特点:

    1. 核心线程数 == 最大线程数(没有救急线程被创建),因此也无需超时时间
    2. 阻塞队列是无界的,可以放任意数量的任务

    评价:适用于任务量已知,相对耗时的任务

    newCachedThreadPool

    public static ExecutorService newCachedThreadPool() {
        return new ThreadPoolExecutor(0, Integer.MAX_VALUE,
                                        60L, TimeUnit.SECONDS,
                                        new SynchronousQueue<Runnable>());
    }
    

    特点:

    1. 核心线程数是 0, 最大线程数是 Integer.MAX_VALUE,救急线程的空闲生存时间是 60s,意味着:
    • 全部都是救急线程(60s 后可以回收)
    • 救急线程可以无限创建
    1. 队列采用了 SynchronousQueue 实现特点是,它没有容量,没有线程来取是放不进去的(一手交钱、一手交货)

    评价:整个线程池表现为线程数会根据任务量不断增长,没有上限,当任务执行完毕,空闲 1分钟后释放线程。 适合任务数比较密集,但每个任务执行时间较短的情况

    newSingleThreadExecutor

    public static ExecutorService newSingleThreadExecutor() {
        return new FinalizableDelegatedExecutorService
            (new ThreadPoolExecutor(1, 1,
                                    0L, TimeUnit.MILLISECONDS,
                                    new LinkedBlockingQueue<Runnable>()));
    }
    

    使用场景:希望多个任务排队执行。线程数固定为 1,任务数多于 1 时,会放入无界队列排队。任务执行完毕,这唯一的线程也不会被释放。

    与自己创建一个线程不断执行任务的区别?

    自己创建一个单线程串行执行任务,如果任务执行失败而终止那么没有任何补救措施,而线程池还会新建一个线程,保证池的正常工作。

    为啥它还要 FinalizableDelegatedExecutorService 包装一下?

    FinalizableDelegatedExecutorService 应用的是装饰器模式,只对外暴露了 ExecutorService 接口,因此不能调用 ThreadPoolExecutor 中特有的方法。而前两个方法对外暴露的是 ThreadPoolExecutor 对象,可以强转后调用 setCorePoolSize 等方法进行修改。

    7.2.4 提交任务

    // 执行任务
    void execute(Runnable command);
    
    // 提交任务 task,用返回值 Future 获得任务执行结果 
    <T> Future<T> submit(Callable<T> task);
    
    // 提交 tasks 中所有任务
    <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks) throws InterruptedException;
    
    // 提交 tasks 中所有任务,带超时时间
    <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit) throws InterruptedException;
    
    // 提交 tasks 中所有任务,哪个任务先成功执行完毕,返回此任务执行结果,其它任务取消 
    <T> T invokeAny(Collection<? extends Callable<T>> tasks) throws InterruptedException, ExecutionException;
    
    // 提交 tasks 中所有任务,哪个任务先成功执行完毕,返回此任务执行结果,其它任务取消,带超时时间 
    <T> T invokeAny(Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit) throws InterruptedException, ExecutionException, TimeoutException;
    

    7.2.5 关闭线程池

    注:模型对接部分生产-消费那个地方的停止可以借鉴这个地方。

    shutdown

    /*
     线程池状态变为 SHUTDOWN
        - 不会接收新任务
        - 但已提交任务会执行完
        - 此方法不会阻塞调用线程的执行
    */
    public void shutdown() {
        final ReentrantLock mainLock = this.mainLock; mainLock.lock();
        try {
            checkShutdownAccess();
            // 修改线程池状态
            advanceRunState(SHUTDOWN);
            // 仅会打断空闲线程
            interruptIdleWorkers();
            onShutdown(); // 扩展点 ScheduledThreadPoolExecutor
        } finally { 
            mainLock.unlock();
        }
        // 尝试终结(没有运行的线程可以立刻终结,如果还有运行的线程也不会等)
        tryTerminate(); 
    }
    

    shutdownNow

    /*
     线程池状态变为 STOP
        - 不会接收新任务
        - 会将队列中的任务返回
        - 并用 interrupt 的方式中断正在执行的任务
    */
    public List<Runnable> shutdownNow() {
        List<Runnable> tasks;
        final ReentrantLock mainLock = this.mainLock; mainLock.lock();
        try {
            checkShutdownAccess(); // 修改线程池状态 
            advanceRunState(STOP); // 打断所有线程 interruptWorkers();
            // 获取队列中剩余任务
            tasks = drainQueue(); 
        } finally {
            mainLock.unlock(); 
        }
        // 尝试终结 
        tryTerminate(); 
        return tasks;
    }
    

    其他方法

    // 不在 RUNNING 状态的线程池,此方法就返回 true 
    boolean isShutdown();
    // 线程池状态是否是 TERMINATED 
    boolean isTerminated();
    // 调用 shutdown 后,由于调用线程并不会等待所有任务运行结束,因此如果它想在线程池 TERMINATED 后做些事情,可以利用此方法等待
    boolean awaitTermination(long timeout, TimeUnit unit) throws InterruptedException;
    

    < 异步模式 —— 工作线程 >

    7.2.6 任务调度线程池

    在『任务调度线程池』功能加入之前,可以使用 java.util.Timer 来实现定时功能,Timer 的优点在于简单易用,但由于所有任务都是由同一个线程来调度,因此所有任务都是串行执行的,同一时间只能有一个任务在执行,前一个任务的延迟或异常都将会影响到之后的任务

    ScheduledExecutorService 使用

    ScheduledExecutorService executor = Executors.newScheduledThreadPool(2); // 添加两个任务,希望它们都在 1s 后执行
    executor.schedule(() -> {
        System.out.println("任务1,执行时间:" + new Date());
        try {
            Thread.sleep(2000);
        } catch (InterruptedException e) {
        }
    }, 1000, TimeUnit.MILLISECONDS);
    executor.schedule(() -> {
        System.out.println("任务2,执行时间:" + new Date());
    }, 1000, TimeUnit.MILLISECONDS);
    
    任务1,执行时间:Thu Jan 03 12:45:17 CST 2019 
    任务2,执行时间:Thu Jan 03 12:45:17 CST 2019
    

    评价:

    整个线程池表现为:线程数固定,任务数多于线程数时,会放入无界队列排队。任务执行完毕,这些线程也不会被释放。用来执行延迟或反复执行的任务

    7.2.7 Tomcat 线程池

    image
    • LimitLatch 用来限流,可以控制最大连接个数,类似 J.U.C 中的 Semaphore
    • Acceptor 只负责【接收新的 socket 连接】
    • Poller 只负责监听 socket channel 是否有【可读的 I/O 事件】一旦可读,封装一个任务对象(socketProcessor),提交给 Executor 线程池处理
    • Executor 线程池中的工作线程最终负责【处理请求】
    image

    Tomcat 线程池扩展了 ThreadPoolExecutor,行为稍有不同。如果总线程数达到 maximumPoolSize,这时不会立刻抛 RejectedExecutionException 异常而是再次尝试将任务放入队列,如果还失败,才抛出 RejectedExecutionException 异常。

    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();
                    Thread.interrupted();
                    throw new RejectedExecutionException(x);
                }
            } else {
                submittedCount.decrementAndGet();
                throw rx;
            }
        }
    }
    
    // TaskQueue.java
    public boolean force(Runnable o, long timeout, TimeUnit unit) throws InterruptedException {
        if (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
    }
    

    Connector 配置

    对应 server.xml 中的 Connector 标签

    image

    Executor 线程配置

    image

    Tomcat中的线程是守护线程,会随着主线程(Tomcat)退出而退出

    这里 Tomcat 用的是无界队列,那么是不是永远都用不到救急线程呢?

    不是,因为Tomcat修改了向队列中添加任务的流程:

    image

    7.2.8 Fork/Join 线程池

    Fork/Join 是 JDK 1.7 加入的新的线程池实现,它体现的是一种分治思想,适用于能够进行任务拆分的cpu 密集型运算

    所谓的任务拆分,是将一个大任务拆分为算法上相同的小任务,直至不能拆分可以直接求解。跟递归相关的一些计算,如归并排序、斐波那契数列、都可以用分治思想进行求解。

    Fork/Join 在分治的基础上加入了多线程,可以把每个任务的分解和合并交给不同的线程来完成,进一步提升了运算效率。

    Fork/Join 默认会创建与 cpu 核心数大小相同的线程池。

    使用

    提交给 Fork/Join 线程池的任务需要继承 RecursiveTask(有返回值)或 RecursiveAction(没有返回值),例如下面定义了一个对 1~n 之间的整数求和的任务

    public class TestForkJoin {
    
        public static void main(String[] args) {
            ForkJoinPool pool = new ForkJoinPool(4);
            System.out.println(pool.invoke(new AddTask1(5)));
        }
    }
    
    @Slf4j(topic = "c.AddTask")
    class AddTask1 extends RecursiveTask<Integer> {
    
        int n;
    
        public AddTask1(int n) {
            this.n = n;
        }
    
        @Override
        public String toString() {
            return "{" + n + '}';
        }
    
        @Override
        protected Integer compute() {
            if (n == 1) {
                log.debug("join() {}", n);
                return n;
            }
            AddTask1 t1 = new AddTask1(n - 1);
    
            t1.fork();
            log.debug("fork() {} + {}", n, t1);
            int result = n + t1.join();
            log.debug("join() {} + {} = {}", n, t1, result);
            return result;
        }
    }
    
    image

    这样的任务拆分很明显是不好的,因为前一个任务依赖后一个任务,相当于同时只有1个线程在工作。

    改进

    class AddTask3 extends RecursiveTask<Integer> {
    
        int begin;
        int end;
    
        public AddTask3(int begin, int end) {
            this.begin = begin;
            this.end = end;
        }
    
        @Override
        public String toString() {
            return "{" + begin + "," + end + '}';
        }
    
        @Override
        protected Integer compute() {
            if (begin == end) {
                log.debug("join() {}", begin);
                return begin;
            }
            if (end - begin == 1) {
                log.debug("join() {} + {} = {}", begin, end, end + begin);
                return end + begin;
            }
            int mid = (end + begin) / 2;
    
            AddTask3 t1 = new AddTask3(begin, mid);
            t1.fork();
            AddTask3 t2 = new AddTask3(mid + 1, end);
            t2.fork();
            log.debug("fork() {} + {} = ?", t1, t2);
    
            int result = t1.join() + t2.join();
            log.debug("join() {} + {} = {}", t1, t2, result);
            return result;
        }
    }
    
    image

    这样就可以同时有多个线程在运行了,上图最多3个。

    7.3 J.U.C

    7.3.1 AQS原理

    全称是 AbstractQueuedSynchronizer,是阻塞式锁和相关的同步器工具的框架。

    1. 用 state 属性来表示资源的状态(分独占模式和共享模式),子类需要定义如何维护这个状态,控制如何获取锁和释放锁
    • getState - 获取 state 状态
    • setState - 设置 state 状态
    • compareAndSetState - cas 机制设置 state 状态
    • 独占模式是只有一个线程能够访问资源,而共享模式可以允许多个线程访问资源
    1. 提供了基于 FIFO 的等待队列,类似于 Monitor 的 EntryList
    2. 条件变量来实现等待、唤醒机制,支持多个条件变量,类似于 Monitor 的 WaitSet
    3. AQS让线程暂停使用的是park、unpark机制

    子类主要实现这样一些方法(默认抛出 UnsupportedOperationException)

    1. tryAcquire
    2. tryRelease
    3. tryAcquireShared
    4. tryReleaseShared
    5. isHeldExclusively

    AQS 要实现的功能目标

    1. 阻塞版本获取锁 acquire 和非阻塞的版本尝试获取锁 tryAcquire
    2. 获取锁超时机制
    3. 通过打断取消机制
    4. 独占机制及共享机制
    5. 条件不满足时的等待机制

    自己实现一个不可重入锁

    @Slf4j(topic = "c.TestAqs")
    public class TestAqs {
        public static void main(String[] args) {
            MyLock lock = new MyLock();
            new Thread(() -> {
                lock.lock();
                try {
                    log.debug("locking...");
                    sleep(1);
                } catch (InterruptedException e) {
                    e.printStackTrace();
                } finally {
                    log.debug("unlocking...");
                    lock.unlock();
                }
            },"t1").start();
    
            new Thread(() -> {
                lock.lock();
                try {
                    log.debug("locking...");
                } finally {
                    log.debug("unlocking...");
                    lock.unlock();
                }
            },"t2").start();
        }
    }
    
    // 自定义锁(不可重入锁)
    class MyLock implements Lock {
    
        // 独占锁  同步器类
        class MySync extends AbstractQueuedSynchronizer {
            // 参数arg是用于重入锁的
            @Override
            protected boolean tryAcquire(int arg) {
                // Cas方式加锁
                if(compareAndSetState(0, 1)) {
                    // 加上了锁,并设置 owner 为当前线程
                    setExclusiveOwnerThread(Thread.currentThread());
                    return true;
                }
                return false;
            }
    
            @Override
            protected boolean tryRelease(int arg) {
                // 因为state使用了volatile修饰而exclusiveOwnerThread没有使用,所以要将setExclusiveOwnerThread写在前面,从而使这2个变量的修改对其他线程可见
                setExclusiveOwnerThread(null);
                setState(0);
                return true;
            }
    
            @Override // 是否持有独占锁
            protected boolean isHeldExclusively() {
                return getState() == 1;
            }
    
            public Condition newCondition() {
                return new ConditionObject();
            }
        }
    
        private MySync sync = new MySync();
    
        @Override // 加锁(不成功会进入等待队列)
        public void lock() {
            sync.acquire(1);
        }
    
        @Override // 加锁,可打断
        public void lockInterruptibly() throws InterruptedException {
            sync.acquireInterruptibly(1);
        }
    
        @Override // 尝试加锁(一次)
        public boolean tryLock() {
            return sync.tryAcquire(1);
        }
    
        @Override // 尝试加锁,带超时
        public boolean tryLock(long time, TimeUnit unit) throws InterruptedException {
            return sync.tryAcquireNanos(1, unit.toNanos(time));
        }
    
        @Override // 解锁
        public void unlock() {
            sync.release(1);
        }
    
        @Override // 创建条件变量
        public Condition newCondition() {
            return sync.newCondition();
        }
    }
    

    AQS 的设计

    要点:

    1. 原子维护 state 状态
    2. 阻塞及恢复线程
    3. 维护队列
    state 设计

    state 使用 volatile 配合 cas 保证其修改时的原子性

    state 使用了 32bit int 来维护同步状态,因为当时使用 long 在很多平台下测试的结果并不理想

    阻塞恢复设计

    早期的控制线程暂停和恢复的 api 有 suspend 和 resume,但它们是不可用的(已废弃),因为如果先调用的 resume 那么 suspend 将感知不到

    解决方法是使用 park & unpark 来实现线程的暂停和恢复,具体原理在之前讲过了,先 unpark 再 park 也没问题

    park & unpark 是针对线程的,而不是针对同步器的,因此控制粒度更为精细

    park 线程还可以通过 interrupt 打断

    队列设计

    使用了 FIFO 先入先出队列,并不支持优先级队列

    设计时借鉴了 CLH 队列,它是一种单向无锁队列

    队列中有 head 和 tail 两个指针节点,都用 volatile 修饰配合 cas 使用,每个节点有 state 维护节点状态。

    CLH 好处:

    1. 无锁,使用自旋
    2. 快速,无阻塞

    AQS 在一些方面改进了 CLH

    // 入队,只有入队是CAS操作,出队不是,因为出队操作只会有一个线程调用
    private Node enq(final Node node) {
        for (; ; ) {
            Node t = tail;
            // 队列中还没有元素 tail 为 null 
            if (t == null) {
                // 将 head 从 null -> dummy
                if (compareAndSetHead(new Node()))
                    tail = head;
            } else {
                // 将 node 的 prev 设置为原来的 tail 
                node.prev = t;
                // 将 tail 从原来的 tail 设置为 node
                if (compareAndSetTail(t, node)) {
                    // 原来 tail 的 next 设置为 node 
                    t.next = node;
                    return t;
                }
            }
        }
    }
    

    7.3.2 ReentrantLock 原理

    image

    1、非公平锁实现原理

    加锁流程

    从构造器开始看,默认为非公平锁实现

    public ReentrantLock() {
        sync = new NonfairSync();
    }
    

    当没有竞争时:

    image

    当第一个竞争出现时:

    image

    Thread-1 执行了

    1. CAS 尝试将 state 由 0 改为 1,结果失败
    2. 进入 tryAcquire 逻辑,这时 state 已经是1,结果仍然失败
    3. 接下来进入 addWaiter 逻辑,构造 Node 队列
    • 图中黄色三角表示该 Node 的 waitStatus 状态,其中 0 为默认正常状态
    • Node 的创建是懒惰的
    • 其中第一个 Node 称为 Dummy(哑元)或哨兵,用来占位,并不关联线程
    image

    当前线程进入 acquireQueued 逻辑

    1. acquireQueued 会在一个死循环中不断尝试获得锁,失败后进入 park 阻塞
    2. 如果自己是紧邻着 head(排第二位),那么再次 tryAcquire 尝试获取锁,当然这时 state 仍为 1,失败
    3. 进入 shouldParkAfterFailedAcquire 逻辑,将前驱 node,即 head 的 waitStatus 改为 -1,这次返回 false
    image
    1. shouldParkAfterFailedAcquire 执行完毕回到 acquireQueued ,再次 tryAcquire 尝试获取锁,当然这时 state 仍为 1,失败
    2. 当再次进入 shouldParkAfterFailedAcquire 时,这时因为其前驱 node 的 waitStatus 已经是 -1,这次返回 true
    3. 进入 parkAndCheckInterrupt,Thread-1 park(灰色表示)
    image

    再次有多个线程经历上述过程竞争失败,变成这个样子

    image

    Thread-0 释放锁,进入 tryRelease 流程

    // Sync 继承自 AQS
    static final class NonfairSync extends Sync {
        private static final long serialVersionUID = 7316153563782823691L;
    
        // 加锁实现
        final void lock() {
            // 首先用 cas 尝试(仅尝试一次)将 state 从 0 改为 1, 如果成功表示获得了独占锁
            if (compareAndSetState(0, 1))
                setExclusiveOwnerThread(Thread.currentThread());
            else
                // 如果尝试失败,进入 (一)
                acquire(1);
        }
    
        // (一) AQS 继承过来的方法, 方便阅读, 放在此处
        public final void acquire(int arg) {
            // (二) tryAcquire
            if (
                    !tryAcquire(arg) &&
                            // 当 tryAcquire 返回为 false 时, 先调用 addWaiter (四), 接着 acquireQueued (五)
                            acquireQueued(addWaiter(Node.EXCLUSIVE), arg)
                    ) {
                selfInterrupt();
            }
        }
    
        // (二) 进入 (三)
        protected final boolean tryAcquire(int acquires) {
            return nonfairTryAcquire(acquires);
        }
    
        // (三) Sync 继承过来的方法, 方便阅读, 放在此处
        final boolean nonfairTryAcquire(int acquires) {
            final Thread current = Thread.currentThread();
            int c = getState();
            // 如果还没有获得锁
            if (c == 0) {
                // 尝试用 cas 获得, 这里体现了非公平性: 不去检查 AQS 队列
                if (compareAndSetState(0, acquires)) {
                    setExclusiveOwnerThread(current);
                    return true;
                }
            }
            // 如果已经获得了锁, 线程还是当前线程, 表示发生了锁重入
            else if (current == getExclusiveOwnerThread()) {
                state++
                int nextc = c + acquires;
                if (nextc < 0) // overflow
                    throw new Error("Maximum lock count exceeded");
                setState(nextc);
                return true;
            }
            // 获取失败, 回到调用处
            return false;
        }
    
        // (四) AQS 继承过来的方法, 方便阅读, 放在此处
        private Node addWaiter(Node mode) {
            // 将当前线程关联到一个 Node 对象上, 模式为独占模式
            Node node = new Node(Thread.currentThread(), mode);
            // 如果 tail 不为 null, cas 尝试将 Node 对象加入 AQS 队列尾部
            Node pred = tail;
            if (pred != null) {
                node.prev = pred;
                if (compareAndSetTail(pred, node)) {
                    // 双向链表
                    pred.next = node;
                    return node;
                }
            }
            // 尝试将 Node 加入 AQS, 进入 (六) 
            enq(node);
            return node;
        }
    
        // (六) AQS 继承过来的方法, 方便阅读, 放在此处
        private Node enq(final Node node) {
            for (; ; ) {
                Node t = tail;
                if (t == null) {
                    // 还没有, 设置 head 为哨兵节点(不对应线程,状态为 0)
                    if (compareAndSetHead(new Node())) {
                        tail = head;
                    }
                } else {
                    // cas 尝试将 Node 对象加入 AQS 队列尾部
                    node.prev = t;
                    if (compareAndSetTail(t, node)) {
                        t.next = node;
                        return t;
                    }
                }
            }
        }
    
        // (五) AQS 继承过来的方法, 方便阅读, 放在此处
        final boolean acquireQueued(final Node node, int arg) {  // node为新加入的节点
            boolean failed = true;
            try {
                boolean interrupted = false;
                for (; ; ) {
                    final Node p = node.predecessor();
                    // 上一个节点是 head, 表示轮到自己(当前线程对应的 node)了, 尝试获取,tryAcquire 会调用 nonfairTryAcquire ,与其他线程竞争锁
                    if (p == head && tryAcquire(arg)) {
                        // 获取成功, 设置自己(当前线程对应的 node)为head
                        setHead(node);
                        // 上一个节点 help GC
                        p.next = null;
                        failed = false;
                        // 返回中断标记 false
                        return interrupted;
                    } 
                    if (
                            // 判断是否应当 park, 进入 (七)
                            shouldParkAfterFailedAcquire(p, node) &&
                                    // park 等待, 此时 Node 的状态被置为 Node.SIGNAL (八)
                                    parkAndCheckInterrupt()
                            ) {
                        interrupted = true;
                    }
                }
            } finally {
                if (failed)
                    cancelAcquire(node);
            }
        }
    
        // (七) AQS 继承过来的方法, 方便阅读, 放在此处
        private static boolean shouldParkAfterFailedAcquire(Node pred, Node node) {
            // 获取上一个节点的状态
            int ws = pred.waitStatus;
            if (ws == Node.SIGNAL) {
                // 上一个节点都在阻塞, 那么自己也阻塞好了
                return true;
            }
            // > 0 表示取消状态 
            if (ws > 0) {
                // 上一个节点取消, 那么重构删除前面所有取消的节点, 返回到外层循环重试
                do {
                    node.prev = pred = pred.prev;
                }
                while (pred.waitStatus > 0);
                pred.next = node;
            } else {
                // 这次还没有阻塞
                // 但下次如果重试不成功, 则需要阻塞,这时需要设置上一个节点状态为 Node.SIGNAL
                compareAndSetWaitStatus(pred, ws, Node.SIGNAL);
            }
            return false;
        }
    
        // (八) 阻塞当前线程
        private final boolean parkAndCheckInterrupt() {
            LockSupport.park(this);
            return Thread.interrupted();
        }
    }
    

    注:是否需要 unpark 是由当前节点的前驱节点的 waitStatus == Node.SIGNAL 来决定,而不是本节点的 waitStatus 决定

    解锁流程

    tryRelease 流程,如果成功:

    1. 设置 exclusiveOwnerThread 为 null
    2. state = 0
    image

    当前队列不为 null,并且 head 的 waitStatus = -1,进入 unparkSuccessor 流程

    找到队列中离 head 最近的一个 Node(没取消的),unpark 恢复其运行,本例中即为

    Thread-1 回到 Thread-1 的 acquireQueued 流程,tryAcquire 方法会获取锁

    image

    如果加锁成功(没有竞争),会设置

    • exclusiveOwnerThread 为 Thread-1,state = 1
    • head 指向刚刚 Thread-1 所在的 Node,该 Node 清空 Thread
    • 原本的 head 因为从链表断开,而可被垃圾回收

    如果这时候有其它线程来竞争(非公平的体现),例如这时有 Thread-4 来了

    image

    如果不巧又被 Thread-4 占了先

    • Thread-4 被设置为 exclusiveOwnerThread,state = 1
    • Thread-1 再次进入 acquireQueued 流程,获取锁失败,重新进入 park 阻塞
    // Sync 继承自 AQS
    static final class NonfairSync extends Sync {
        // 解锁实现
        public void unlock() {
            sync.release(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final boolean release(int arg) {
            // 尝试释放锁, 进入 (一)
            if (tryRelease(arg)) {
                // 队列头节点 unpark
                Node h = head;
                if (
                        // 队列不为 null
                        h != null &&
                                // waitStatus == Node.SIGNAL 才需要 unpark
                                h.waitStatus != 0
                        ) {
                    unparkSuccessor(h);
                }
                return true;
            }
            return false;
        }
    
        // (一) Sync 继承过来的方法, 方便阅读, 放在此处
        protected final boolean tryRelease(int releases) {
            // state-- 针对锁重入
            int c = getState() - releases;
            if (Thread.currentThread() != getExclusiveOwnerThread())
                throw new IllegalMonitorStateException();
            boolean free = false;
            // 支持锁重入, 只有 state 减为 0, 才释放成功
            if (c == 0) {
                free = true;
                setExclusiveOwnerThread(null);
            }
            setState(c);
            return free;
        }
    
        // (二) AQS 继承过来的方法, 方便阅读, 放在此处
        private void unparkSuccessor(Node node) {
            // 如果状态为 Node.SIGNAL 尝试重置状态为 0
            // 不成功也可以
            int ws = node.waitStatus;
            if (ws < 0) {
                compareAndSetWaitStatus(node, ws, 0);
            }
            // unpark AQS 中等待的线程, 进入 (二)
            // 找到需要 unpark 的节点, 但本节点从 AQS 队列中脱离, 是由唤醒节点完成的
            Node s = node.next;
            // 不考虑已取消的节点, 从 AQS 队列从后至前找到队列最前面需要 unpark 的节点
            if (s == null || s.waitStatus > 0) {
                s = null;
                for (Node t = tail; t != null && t != node; t = t.prev)
                    if (t.waitStatus <= 0) s = t;
            }
            if (s != null)
                LockSupport.unpark(s.thread);
        }
    }
    

    2、可重入原理

    static final class NonfairSync extends Sync { // ...
        // Sync 继承过来的方法, 方便阅读, 放在此处
        final boolean nonfairTryAcquire(int acquires) {
            final Thread current = Thread.currentThread();
            int c = getState();
            if (c == 0) {
                if (compareAndSetState(0, acquires)) {
                    setExclusiveOwnerThread(current);
                    return true;
                }
            }
            // 如果已经获得了锁, 线程还是当前线程, 表示发生了锁重入 
            else if (current == getExclusiveOwnerThread()) {
                // state++
                int nextc = c + acquires;
                if (nextc < 0) // overflow
                    throw new Error("Maximum lock count exceeded");
                setState(nextc);
                return true;
            }
            return false;
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        protected final boolean tryRelease(int releases) {
            // state--
            int c = getState() - releases;
            if (Thread.currentThread() != getExclusiveOwnerThread())
                throw new IllegalMonitorStateException();
            boolean free = false;
            // 支持锁重入, 只有 state 减为 0, 才释放成功
            if (c == 0) {
                free = true;
                setExclusiveOwnerThread(null);
            }
    
            setState(c);
            return free;
        }
    }
    

    3、可打断原理

    不可打断模式
    // Sync 继承自 AQS
    static final class NonfairSync extends Sync {
        // ...
    
        private final boolean parkAndCheckInterrupt() { // 如果打断标记已经是 true, 则 park 会失效
            LockSupport.park(this);
            // interrupted 会清除打断标记
            return Thread.interrupted();
        }
    
        final boolean acquireQueued(final Node node, int arg) {
            boolean failed = true;
            try {
                boolean interrupted = false;
                for (; ; ) {
                    final Node p = node.predecessor();
                    if (p == head && tryAcquire(arg)) {
                        setHead(node);
                        p.next = null;
                        failed = false;
                        // 还是需要获得锁后, 才能返回打断状态
                        return interrupted;
                    }
                    if (shouldParkAfterFailedAcquire(p, node) &&
                                    parkAndCheckInterrupt()) {
                        // 如果是因为 interrupt 被唤醒, 返回打断状态为 true
                        interrupted = true;
                    }
                }
            } finally {
                if (failed) cancelAcquire(node);
            }
        }
    
        public final void acquire(int arg) {
            if (!tryAcquire(arg) && acquireQueued(addWaiter(Node.EXCLUSIVE), arg)) {
                // 如果打断状态为 true
                selfInterrupt();
            }
        }
    
        static void selfInterrupt() {
            // 重新产生一次中断 Thread.currentThread().interrupt();
        }
    }
    
    可打断模式
    static final class NonfairSync extends Sync {
        public final void acquireInterruptibly(int arg) throws InterruptedException {
            if (Thread.interrupted())
                throw new InterruptedException();
            // 如果没有获得到锁, 进入 (一)
            if (!tryAcquire(arg))
                doAcquireInterruptibly(arg);
        }
    
        // (一) 可打断的获取锁流程
        private void doAcquireInterruptibly(int arg) throws InterruptedException {
            final Node node = addWaiter(Node.EXCLUSIVE);
            boolean failed = true;
            try {
                for (; ; ) {
                    final Node p = node.predecessor();
                    if (p == head && tryAcquire(arg)) {
                        setHead(node);
                        p.next = null; // help GC failed = false;
                        return;
                    }
                    if (shouldParkAfterFailedAcquire(p, node) &&
                            parkAndCheckInterrupt()) {
                        // 在 park 过程中如果被 interrupt 会进入此
                        // 这时候抛出异常, 而不会再次进入 for (;;)
                        throw new InterruptedException();
                    }
                }
            } finally {
                if (failed)
                    cancelAcquire(node);
            }
        }
    }
    

    4、公平锁实现原理

    每个条件变量其实就对应着一个等待队列,其实现类是 ConditionObject

    await 流程

    开始 Thread-0 持有锁,调用 await,进入 ConditionObject 的 addConditionWaiter 流程,创建新的 Node 状态为 -2(Node.CONDITION),关联 Thread-0,加入等待队列尾部

    image

    接下来进入 AQS 的 fullyRelease 流程,释放同步器上的锁,

    image

    并unpark AQS 队列中的下一个节点竞争锁,假设没有其他竞争线程,那么 Thread-1 竞争成功

    image

    park 阻塞 Thread-0

    image
    signal 流程

    假设 Thread-1 要来唤醒 Thread-0

    image

    首先判断 Thread-1 是否持有锁,如果持有则进入 ConditionObject 的 doSignal 流程,取得等待队列中第一个 Node,即 Thread-0 所在 Node

    image

    执行 transferForSignal 流程,将该 Node 加入 AQS 队列尾部,将 Thread-0 的 waitStatus 改为 0,Thread-3 的 waitStatus 改为 -1

    image

    Thread-1 释放锁,进入 unlock 流程,后续流程略

    static final class FairSync extends Sync {
        private static final long serialVersionUID = -3000897897090466540L;
    
        final void lock() {
            acquire(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final void acquire(int arg) {
            if (
                    !tryAcquire(arg) && acquireQueued(addWaiter(Node.EXCLUSIVE), arg)
                    ) {
                selfInterrupt();
            }
        }
    
        // 与非公平锁主要区别在于 tryAcquire 方法的实现
        protected final boolean tryAcquire(int acquires) {
            final Thread current = Thread.currentThread();
            int c = getState();
            if (c == 0) {
                // 先检查 AQS 队列中是否有前驱节点, 没有才去竞争 
                if (!hasQueuedPredecessors() && compareAndSetState(0, acquires)){
                    setExclusiveOwnerThread(current);
                    return true;
                }
            } else if (current == getExclusiveOwnerThread()) {
                int nextc = c + acquires;
                if (nextc < 0)
                    throw new Error("Maximum lock count exceeded");
                setState(nextc);
                return true;
            }
            return false;
        }
    
        // (一) AQS 继承过来的方法, 方便阅读, 放在此处
        public final boolean hasQueuedPredecessors() {
            Node t = tail;
            Node h = head;
            Node s;
            // h != t 时表示队列中有 Node
            return h != t &&
                    (
                    // (s = h.next) == null 表示队列中还有没有老二
                    (s = h.next) == null ||
                    // 或者队列中老二线程不是此线程
                    s.thread != Thread.currentThread());
        }
    }
    

    5、条件变量实现原理

    class ConditionObject implements Condition, java.io.Serializable {
        private static final long serialVersionUID = 1173984872572414699L;
    
        // 第一个等待节点
        private transient Node firstWaiter;
        // 最后一个等待节点
        private transient Node lastWaiter;
    
        public ConditionObject() {
        }
    
        // (一) 添加一个 Node 至等待队列
        private Node addConditionWaiter() {
            Node t = lastWaiter;
            // 所有已取消的 Node 从队列链表删除, 见 (二)
            if (t != null && t.waitStatus != Node.CONDITION) {
                unlinkCancelledWaiters();
                t = lastWaiter;
            }
            // 创建一个关联当前线程的新 Node, 添加至队列尾部
            Node node = new Node(Thread.currentThread(), Node.CONDITION);
            if (t == null)
                firstWaiter = node;
            else
                t.nextWaiter = node;
            lastWaiter = node;
            return node;
        }
    
        // 唤醒 - 将没取消的第一个节点转移至 AQS 队列
        private void doSignal(Node first) {
            do {
                // 已经是尾节点了
                if ((firstWaiter = first.nextWaiter) == null) {
                    lastWaiter = null;
                }
                first.nextWaiter = null;
            } while (
                // 将等待队列中的 Node 转移至 AQS 队列, 不成功且还有节点则继续循环 (三),当等待队列中的线程被打断或者超时时,这个就会转移失败
                    !transferForSignal(first) &&
                            // 队列还有节点,那么重新移动这个新first 节点
                            (first = firstWaiter) != null
                    );
        }
    
        // 外部类方法, 方便阅读, 放在此处
        // (三) 如果节点状态是取消, 返回 false 表示转移失败, 否则转移成功
        final boolean transferForSignal(Node node) {
            // 如果状态已经不是 Node.CONDITION, 说明被取消了
            if (!compareAndSetWaitStatus(node, Node.CONDITION, 0))
                return false;
            // 加入 AQS 队列尾部
            Node p = enq(node);
            int ws = p.waitStatus;
            if (
                    // 上一个节点被取消
                    ws > 0 ||
                            // 上一个节点不能设置状态为 Node.SIGNAL
                            !compareAndSetWaitStatus(p, ws, Node.SIGNAL)
                    ) {
                LockSupport.unpark(node.thread);
            }
            return true;
        }
    
        // unpark 取消阻塞, 让线程重新同步状态
        // 全部唤醒 - 等待队列的所有节点转移至 AQS 队列
        private void doSignalAll(Node first) {
            lastWaiter = firstWaiter = null;
            do {
                Node next = first.nextWaiter;
                first.nextWaiter = null;
                transferForSignal(first);
                first = next;
            } while (first != null);
        }
    
        // (二)
        private void unlinkCancelledWaiters() {
            // ...
        }
    
        // 唤醒 - 必须持有锁才能唤醒, 因此 doSignal 内无需考虑加锁
        public final void signal() {
            if (!isHeldExclusively())
                throw new IllegalMonitorStateException();
            Node first = firstWaiter;
            if (first != null)
                doSignal(first);
        }
    
        // 全部唤醒 - 必须持有锁才能唤醒, 因此 doSignalAll 内无需考虑加锁
        public final void signalAll() {
            if (!isHeldExclusively())
                throw new IllegalMonitorStateException();
            Node first = firstWaiter;
            if (first != null)
                doSignalAll(first);
        }
    
        // 不可打断等待 - 直到被唤醒
        public final void awaitUninterruptibly() {
            // 添加一个 Node 至等待队列, 见 (一)
            Node node = addConditionWaiter(); // 释放节点持有的锁, 见 (四)
            int savedState = fullyRelease(node);
            boolean interrupted = false;
            // 如果该节点还没有转移至 AQS 队列, 阻塞
            while (!isOnSyncQueue(node)) {
                // park 阻塞
                LockSupport.park(this);
                // 如果被打断, 仅设置打断状态
                if (Thread.interrupted())
                    interrupted = true;
            }
            // 唤醒后, 尝试竞争锁, 如果失败进入 AQS 队列
            if (acquireQueued(node, savedState) || interrupted)
                selfInterrupt();
        }
    
        // 外部类方法, 方便阅读, 放在此处
        // (四) 因为某线程可能重入,需要将 state 全部释放
        final int fullyRelease(Node node) {
            boolean failed = true;
            try {
                int savedState = getState();
                if (release(savedState)) {
                    failed = false;
                    return savedState;
                } else {
                    throw new IllegalMonitorStateException();
                }
            } finally {
                if (failed)
                    node.waitStatus = Node.CANCELLED;
            }
        }
    
        // 打断模式 - 在退出等待时重新设置打断状态
        private static final int REINTERRUPT = 1; // 打断模式 - 在退出等待时抛出异常
        private static final int THROW_IE = -1;
    
        // 判断打断模式
        private int checkInterruptWhileWaiting(Node node) {
            return Thread.interrupted() ?
                    (transferAfterCancelledWait(node) ? THROW_IE : REINTERRUPT) :
                    0;
        }
    
        // (五) 应用打断模式
        private void reportInterruptAfterWait(int interruptMode)
                throws InterruptedException {
            if (interruptMode == THROW_IE)
                throw new InterruptedException();
            else if (interruptMode == REINTERRUPT)
                selfInterrupt();
        }
    
        // 等待 - 直到被唤醒或打断
        public final void await() throws InterruptedException {
            if (Thread.interrupted()) {
                throw new InterruptedException();
            }
            // 添加一个 Node 至等待队列, 见 (一)
            Node node = addConditionWaiter(); 
            // 释放节点持有的锁,释放到最后一个锁的时候,会唤醒AQS等待队列中的一个线程
            int savedState = fullyRelease(node);
            int interruptMode = 0;
            // 如果该节点还没有转移至 AQS 队列, 阻塞
            while (!isOnSyncQueue(node)) {
                // park 阻塞
                LockSupport.park(this);
                // 如果被打断, 退出等待队列
                if ((interruptMode = checkInterruptWhileWaiting(node)) != 0)
                    break;
            }
            // 退出等待队列后, 还需要获得 AQS 队列的锁,acquireQueued()方法重新获取释放调的那些锁
            if (acquireQueued(node, savedState) && interruptMode != THROW_IE)
                interruptMode = REINTERRUPT;
            // 所有已取消的 Node 从队列链表删除, 见 (二)
            if (node.nextWaiter != null)
                unlinkCancelledWaiters(); // 应用打断模式, 见 (五)
            if (interruptMode != 0)
                reportInterruptAfterWait(interruptMode);
        }
    
        // 等待 - 直到被唤醒或打断或超时
        public final long awaitNanos(long nanosTimeout) throws InterruptedException {
            if (Thread.interrupted()) {
                throw new InterruptedException();
            }
            // 添加一个 Node 至等待队列, 见 (一)
            Node node = addConditionWaiter(); // 释放节点持有的锁
            int savedState = fullyRelease(node); // 获得最后期限
            final long deadline = System.nanoTime() + nanosTimeout;
            int interruptMode = 0;
            // 如果该节点还没有转移至 AQS 队列, 阻塞
            while (!isOnSyncQueue(node)) {
                // 已超时, 退出等待队列
                if (nanosTimeout <= 0L) {
                    transferAfterCancelledWait(node);
                    break;
                }
                // park 阻塞一定时间, spinForTimeoutThreshold 为 1000 ns
                if (nanosTimeout >= spinForTimeoutThreshold)
                    LockSupport.parkNanos(this, nanosTimeout);
                // 如果被打断, 退出等待队列
                if ((interruptMode = checkInterruptWhileWaiting(node)) != 0)
                    break;
                nanosTimeout = deadline - System.nanoTime();
            }
            // 退出等待队列后, 还需要获得 AQS 队列的锁
            if (acquireQueued(node, savedState) && interruptMode != THROW_IE)
                interruptMode = REINTERRUPT;
            // 所有已取消的 Node 从队列链表删除, 见 (二)
            if (node.nextWaiter != null)
                unlinkCancelledWaiters(); // 应用打断模式, 见 (五)
            if (interruptMode != 0)
                reportInterruptAfterWait(interruptMode);
            return deadline - System.nanoTime();
        }
    
        // 等待 - 直到被唤醒或打断或超时, 逻辑类似于 awaitNanos
        public final boolean awaitUntil(Date deadline) throws InterruptedException {
            // ...
        }
    
        // 等待 - 直到被唤醒或打断或超时, 逻辑类似于 awaitNanos
        public final boolean await(long time, TimeUnit unit) throws InterruptedException {
            // ...
        }
        
        // 工具方法 省略 ...
    }
    

    7.3.3 读写锁(以 ReentrantReadWriteLock 为主)

    当读操作远远高于写操作时,这时候使用 读写锁让 读-读 可以并发,提高性能。

    类似于数据库中的 select ... from ... lock in share mode

    注意:

    • 读锁不支持条件变量
    • 重入时升级不支持:即持有读锁的情况下去获取写锁,会导致获取写锁永久等待
    • 重入时降级支持:即持有写锁的情况下去获取读锁

    7.3.3.1 使用读写锁实现缓存

    观察下列代码有什么问题

    class GenericCachedDao<T> {
        // HashMap 作为缓存非线程安全, 需要保护
        HashMap<SqlPair, T> map = new HashMap<>();
    
        public int update(String sql, Object... params) {
            SqlPair key = new SqlPair(sql, params);
            map.clear();
            int rows = genericDao.update(sql, params);
            return rows;
        }
    
        public T queryOne(Class<T> beanClass, String sql, Object... params) {
            SqlPair key = new SqlPair(sql, params);
    
            T value = map.get(key);
            if (value != null) {
                return value;
            }
            
            // 如果没有, 查询数据库
            value = genericDao.queryOne(beanClass, sql, params);
            map.put(key, value);
            return value;
        }
    
    }
    
    1. 多线程访问queryOne方法时,会导致大量请求到达数据库层
    2. HashMap 线程不安全,会导致数据丢失等问题
    3. update方法中,先清除缓存,后更新数据库数据会导致下列问题
    先清缓存,再更新数据库 先更新数据库,再清缓存

    会有一部分时间,返回的数据是错误的,但最终是正确的

    解决办法:采用读写锁

    class GenericCachedDao<T> {
        // HashMap 作为缓存非线程安全, 需要保护
        HashMap<SqlPair, T> map = new HashMap<>();
        ReentrantReadWriteLock lock = new ReentrantReadWriteLock();
        GenericDao genericDao = new GenericDao();
    
        public int update(String sql, Object... params) {
            SqlPair key = new SqlPair(sql, params);
            // 加写锁, 防止其它线程对缓存读取和更改
    
            lock.writeLock().lock();
            try {
                int rows = genericDao.update(sql, params);
                map.clear();
                return rows;
            } finally {
                lock.writeLock().unlock();
            }
        }
    
        public T queryOne(Class<T> beanClass, String sql, Object... params) {
            SqlPair key = new SqlPair(sql, params);
            // 加读锁, 防止其它线程对缓存更改
            lock.readLock().lock();
            try {
                T value = map.get(key);
                if (value != null) {
                    return value;
                }
            } finally {
                lock.readLock().unlock();
            }
            // 加写锁, 防止其它线程对缓存读取和更改
            lock.writeLock().lock();
            try {
                // get 方法上面部分是可能多个线程进来的, 可能已经向缓存填充了数据
                // 为防止重复查询数据库, 再次验证
                T value = map.get(key);
                if (value == null) {
                    // 如果没有, 查询数据库
                    value = genericDao.queryOne(beanClass, sql, params);
                    map.put(key, value);
                }
                return value;
            } finally {
                lock.writeLock().unlock();
            }
        }
    }
    
    // 作为 key 保证其是不可变的
    class SqlPair {
        private String sql;
        private Object[] params;
    
        public SqlPair(String sql, Object[] params) {
            this.sql = sql;
            this.params = params;
        }
    
        @Override
        public boolean equals(Object o) {
            if (this == o) return true;
            if (o == null || getClass() != o.getClass()) return false;
            SqlPair sqlPair = (SqlPair) o;
            return Objects.equals(sql, sqlPair.sql) &&
                    Arrays.equals(params, sqlPair.params);
        }
    
        @Override
        public int hashCode() {
    
            int result = Objects.hash(sql);
            result = 31 * result + Arrays.hashCode(params);
            return result;
        }
    }
    
    1. 多线程访问queryOne方法时,会导致大量请求到达数据库层 => 会阻塞在获取读锁或者写锁那
    2. HashMap 线程不安全,会导致数据丢失等问题 => 由于加了写锁,同一时刻只有一个线程在写
    3. update方法中,先清除缓存,后更新数据库数据会导致下列问题 => 清楚缓存和更新操作被写锁整成了原子操作。

    读写锁的双重检查与sync的双重检查区别?

    sync

    T1 写数据

    T2 获取锁

    RWL

    T1 写数据

    T2 可能在获取读锁,也可能获取写锁,如果多个线程获取的都是读锁效率比sync高。因为获取sync后要串行执行。

    注意:以上实现体现的是读写锁的应用,保证缓存和数据库的一致性,但有下面的问题没有考虑

    • 适合读多写少,如果写操作比较频繁,以上实现性能低
    • 没有考虑缓存容量
    • 没有考虑缓存过期
    • 只适合单机
    • 并发性还是低,目前只会用一把锁
    • 更新方法太过简单粗暴,清空了所有 key(考虑按类型分区或重新设计 key)

    7.3.3.2 原理

    读写锁用的是同一个 Sycn 同步器,因此等待队列、state 等也是同一个

    t1 w.lock(),t2 r.lock()

    1)t1 成功上锁,流程与 ReentrantLock 加锁相比没有特殊之处,不同是写锁状态占了 state 的低 16 位,而读锁使用的是 state 的高 16 位

    image
    // 写锁上锁
    static final class NonfairSync extends Sync { // ... 省略无关代码
        // 外部类 WriteLock 方法, 方便阅读, 放在此处
        public void lock() {
            sync.acquire(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final void acquire(int arg) {
            if (
                    // 尝试获得写锁失败
                    !tryAcquire(arg) &&
                            // 将当前线程关联到一个 Node 对象上, 模式为独占模式
                            // 进入 AQS 队列阻塞
                            acquireQueued(addWaiter(Node.EXCLUSIVE), arg)
                    ) {
                selfInterrupt();
            }
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        protected final boolean tryAcquire(int acquires) {
            // 获得低 16 位, 代表写锁的 state 计数 
            Thread current = Thread.currentThread();
            int c = getState();
            // 写位
            int w = exclusiveCount(c);
            if (c != 0) {
                if (
                        // c != 0 and w == 0 表示有读锁, 或者 
                        w == 0 ||
                                // 如果 exclusiveOwnerThread 不是自己 
                                current != getExclusiveOwnerThread()
                        ) {
                    // 获得锁失败
                    return false;
                }
                // 写锁计数超过低 16 位, 报异常
                if (w + exclusiveCount(acquires) > MAX_COUNT)
                    throw new Error("Maximum lock count exceeded"); 
                // 写锁重入, 获得锁成功
                setState(c + acquires);
                return true;
            }
            if (    // 判断写锁是否该阻塞, 或者 
                    writerShouldBlock() ||
                            // 尝试更改计数失败 
                            !compareAndSetState(c, c + acquires)
                    ) {
                // 获得锁失败
                return false;
            }
            // 获得锁成功 
            setExclusiveOwnerThread(current);
            return true;
        }
    
        // 非公平锁 writerShouldBlock 总是返回 false, 无需阻塞 
        final boolean writerShouldBlock() {
            return false;
        }
    }
    

    2)t2 执行 r.lock,这时进入读锁的 sync.acquireShared(1) 流程,首先会进入 tryAcquireShared 流程。如果有写锁占据,那么 tryAcquireShared 返回 -1 表示失败

    tryAcquireShared 返回值表示:

    • -1 表示失败
    • 0 表示成功,但后继节点不会继续唤醒(信号量处使用,表示可用资源数, 为 0 则不会继续传播)
    • 正数表示成功,而且数值是还有几个后继节点需要唤醒,读写锁返回 1
    image

    3)这时会进入 sync.doAcquireShared(1) 流程,首先也是调用 addWaiter 添加节点,不同之处在于节点被设置为 Node.SHARED 模式而非 Node.EXCLUSIVE 模式,注意此时 t2 仍处于活跃状态

    image

    4)t2 会看看自己的节点是不是老二,如果是,还会再次调用 tryAcquireShared(1) 来尝试获取锁

    5)如果没有成功,在 doAcquireShared 内 for (;;) 循环一次,把前驱节点的 waitStatus 改为 -1,再 for (;;) 循环一次尝试 tryAcquireShared(1) 如果还不成功,那么在 parkAndCheckInterrupt() 处 park

    image
    t3 r.lock,t4 w.lock

    这种状态下,假设又有 t3 加读锁和 t4 加写锁,这期间 t1 仍然持有锁,就变成了下面的样子

    image
    // 读锁加锁流程
    static final class NonfairSync extends Sync {
        // ReadLock 方法, 方便阅读, 放在此处
        public void lock() {
            sync.acquireShared(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final void acquireShared(int arg) {
            // tryAcquireShared 返回负数, 表示获取读锁失败
            if (tryAcquireShared(arg) < 0) {
                doAcquireShared(arg);
            }
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        protected final int tryAcquireShared(int unused) {
            Thread current = Thread.currentThread();
            int c = getState();
            // 如果是其它线程持有写锁, 获取读锁失败
            // 如果写锁state不为0,或者获取写锁的不是当前线程,则返回-1(此处体现了锁的降级原理)
            if (
                    exclusiveCount(c) != 0 &&
                            getExclusiveOwnerThread() != current) {
                return -1;
            }
            int r = sharedCount(c);
            if (
                    // 读锁不该阻塞(如果老二是写锁,读锁该阻塞), 并且
                    !readerShouldBlock() &&
                            // 小于读锁计数, 并且
                            r < MAX_COUNT &&
                            // 尝试增加计数成功
                            compareAndSetState(c, c + SHARED_UNIT)) {
                // ... 省略不重要的代码
                return 1;
            }
            return fullTryAcquireShared(current);
        }
    
        // 非公平锁 readerShouldBlock 看 AQS 队列中第一个节点是否是写锁
        // true 则该阻塞, false 则不阻塞
        final boolean readerShouldBlock() {
            return apparentlyFirstQueuedIsExclusive();
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        // 与 tryAcquireShared 功能类似, 但会不断尝试 for (;;) 获取读锁, 执行过程中无阻塞
        final int fullTryAcquireShared(Thread current) {
            HoldCounter rh = null;
            for (; ; ) {
                int c = getState();
                if (exclusiveCount(c) != 0) {
                    if (getExclusiveOwnerThread() != current) return -1;
                } else if (readerShouldBlock()) {
                    // ... 省略不重要的代码
                }
                if (sharedCount(c) == MAX_COUNT)
                    throw new Error("Maximum lock count exceeded");
                if (compareAndSetState(c, c + SHARED_UNIT)) {
                    // ... 省略不重要的代码
                    return 1;
                }
            }
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        private void doAcquireShared(int arg) {
            // 将当前线程关联到一个 Node 对象上, 模式为**共享模式**
            final Node node = addWaiter(Node.SHARED);
            boolean failed = true;
            try {
                boolean interrupted = false;
                for (; ; ) {
                    final Node p = node.predecessor();
                    if (p == head) {
                        // 再一次尝试获取读锁
                        int r = tryAcquireShared(arg); // 成功
                        if (r >= 0) {
                            // (一)
                            // r 表示可用资源数, 在这里总是 1 允许传播
                            // (唤醒 AQS 中下一个 Share 节点)
                            setHeadAndPropagate(node, r);
                            p.next = null; // help GC
                            if (interrupted)
                                selfInterrupt();
                            failed = false;
                            return;
                        }
                    }
                    if (
                            // 是否在获取读锁失败时阻塞(前一个阶段 waitStatus == Node.SIGNAL) 返回false,还需要循环一次
                            shouldParkAfterFailedAcquire(p, node) &&
                                    // park 当前线程
                                    parkAndCheckInterrupt()
                            ) {
                        interrupted = true;
                    }
                }
            } finally {
                if (failed)
                    cancelAcquire(node);
            }
        }
    
        // (一) AQS 继承过来的方法, 方便阅读, 放在此处
        private void setHeadAndPropagate(Node node, int propagate) {
            Node h = head; // Record old head for check below // 设置自己为 head
            setHead(node);
            // propagate 表示有共享资源(例如共享读锁或信号量)
            // 原 head waitStatus == Node.SIGNAL 或 Node.PROPAGATE 
            // 现在 head waitStatus == Node.SIGNAL 或 Node.PROPAGATE
            if (propagate > 0 || h == null || h.waitStatus < 0 ||
                    (h = head) == null || h.waitStatus < 0) {
                Node s = node.next;
                // 如果是最后一个节点或者是等待共享读锁的节点
                if (s == null || s.isShared()) {
                    // 进入 (二)
                    doReleaseShared();
                }
            }
        }
    
        // (二) AQS 继承过来的方法, 方便阅读, 放在此处
        private void doReleaseShared() {
            // 如果 head.waitStatus == Node.SIGNAL ==> 0 成功, 下一个节点 unpark
            // 如果 head.waitStatus == 0 ==> Node.PROPAGATE, 为了解决 bug, 见后面分析
            for (; ; ) {
                Node h = head;
                // 队列还有节点
                if (h != null && h != tail) {
                    int ws = h.waitStatus;
                    if (ws == Node.SIGNAL) {
                        // 此处是将头结点的值cas操作从-1改为0,目的为避免其他线程的干扰,导致多次唤醒下一节点
                        if (!compareAndSetWaitStatus(h, Node.SIGNAL, 0)) 
                            continue;
                        // 下一个节点 unpark 如果成功获取读锁
                        // 并且下下个节点还是 shared, 继续 doReleaseShared
                        unparkSuccessor(h);
                    } else if (ws == 0 &&
                            !compareAndSetWaitStatus(h, 0, Node.PROPAGATE))
                        continue;
                }
                if (h == head)
                    break;
            }
        }
    }
    
    t1 w.unlock

    这时会走到写锁的 sync.release(1) 流程,调用 sync.tryRelease(1) 成功,变成下面的样子

    image

    接下来执行唤醒流程 sync.unparkSuccessor ,即让老二恢复运行,这时 t2 在 doAcquireShared 内 parkAndCheckInterrupt() 处恢复运行。这回再来一次 for(;;) 执行 tryAcquireShared 成功则让读锁计数加一。(代码在上面)

    image

    这时 t2 已经恢复运行,接下来 t2 调用 setHeadAndPropagate(node, 1),它原本所在节点被置为头节点

    image

    事情还没完,在 setHeadAndPropagate 方法内还会检查下一个节点是否是 shared,如果是则调用 doReleaseShared() 将 head 的状态从 -1 改为 0 并唤醒老二,这时 t3 在 doAcquireShared 内 parkAndCheckInterrupt() 处恢复运行

    image

    这回再来一次 for (;;) 执行 tryAcquireShared 成功则让读锁计数加一

    image

    这时 t3 已经恢复运行,接下来 t3 调用 setHeadAndPropagate(node, 1),它原本所在节点被置为头节点

    image

    下一个节点不是 shared 了,因此不会继续唤醒 t4 所在节点;所以,如果Ex后面还有Share的线程也不会唤醒。

    // 释放写锁
    static final class NonfairSync extends Sync { // ... 省略无关代码
        // WriteLock 方法, 方便阅读, 放在此处
        public void unlock() {
            sync.release(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final boolean release(int arg) {
            // 尝试释放写锁成功
            if (tryRelease(arg)) {
                // unpark AQS 中等待的线程
                Node h = head;
                if (h != null && h.waitStatus != 0)
                    unparkSuccessor(h);
                return true;
            }
            return false;
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        protected final boolean tryRelease(int releases) {
            if (!isHeldExclusively())
                throw new IllegalMonitorStateException();
            int nextc = getState() - releases;
            // 因为可重入的原因, 写锁计数为 0, 才算释放成功 
            boolean free = exclusiveCount(nextc) == 0;
            if (free) {
                setExclusiveOwnerThread(null);
            }
            setState(nextc);
            return free;
        }
    }
    
    t2 r.unlock,t3 r.unlock

    t2 进入 sync.releaseShared(1) 中,调用 tryReleaseShared(1) 让计数减一,但由于计数还不为零,返回false,不能向下执行。

    image

    t3 进入 sync.releaseShared(1) 中,调用 tryReleaseShared(1) 让计数减一,这回计数为零了,进入 doReleaseShared() 将头节点从 -1 改为 0 并唤醒老二,即

    image

    之后 t4 在 acquireQueued 中 parkAndCheckInterrupt 处恢复运行,再次 for (;;) 这次自己是老二,并且没有其他竞争,tryAcquire(1) 成功,修改头结点,流程结束

    image

    之后 t4 释放锁,结束。

    // 读锁释放
    static final class NonfairSync extends Sync {
        // ReadLock 方法, 方便阅读, 放在此处
        public void unlock() {
            sync.releaseShared(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final boolean releaseShared(int arg) {
            if (tryReleaseShared(arg)) {
                doReleaseShared();
                return true;
            }
            return false;
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        protected final boolean tryReleaseShared(int unused) {
            // ... 省略不重要的代码
            for (; ; ) {
                int c = getState();
                int nextc = c - SHARED_UNIT;
                if (compareAndSetState(c, nextc)) {
                    // 读锁的计数不会影响其它获取读锁线程, 但会影响其它获取写锁线程
                    // 计数为 0 才是真正释放
                    return nextc == 0;
                }
    
            }
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        private void doReleaseShared() {
            // 如果 head.waitStatus == Node.SIGNAL ==> 0 成功, 下一个节点 unpark
            // 如果 head.waitStatus == 0 ==> Node.PROPAGATE
            for (; ; ) {
                Node h = head;
                if (h != null && h != tail) {
                    int ws = h.waitStatus;
                    // 如果有其它线程也在释放读锁,那么需要将 waitStatus 先改为 0
                    // 防止 unparkSuccessor 被多次执行
                    if (ws == Node.SIGNAL) {
                        if (!compareAndSetWaitStatus(h, Node.SIGNAL, 0)) continue;
                        unparkSuccessor(h);
                    }
                    // 如果已经是 0 了,改为 -3,用来解决传播性,见后文信号量 bug 分析 
                    else if (ws == 0 &&
                            !compareAndSetWaitStatus(h, 0, Node.PROPAGATE))
                        continue;
                }
                if (h == head)
                    break;
            }
        }
    }
    

    7.3.3.3 StampedLock

    该类自 JDK 8 加入,是为了进一步优化读性能(因为读写锁每次加读锁的时候,都要做一次cas操作,性能不如不加锁),它的特点是在使用读锁、写锁时都必须配合【戳】使用

    注意:

    • StampedLock 不支持条件变量
    • StampedLock 不支持可重入
    @Slf4j(topic = "c.TestStampedLock")
    public class TestStampedLock {
        public static void main(String[] args) {
            DataContainerStamped dataContainer = new DataContainerStamped(1);
            new Thread(() -> {
                dataContainer.read(1);
            }, "t1").start();
            sleep(0.5);
            new Thread(() -> {
                dataContainer.read(0);
            }, "t2").start();
        }
    }
    
    @Slf4j(topic = "c.DataContainerStamped")
    class DataContainerStamped {
        private int data;
        private final StampedLock lock = new StampedLock();
    
        public DataContainerStamped(int data) {
            this.data = data;
        }
    
        public int read(int readTime) {
            // 乐观读,StampedLock 支持 tryOptimisticRead() 方法(乐观读),读取完毕后需要做一次戳校验 如果校验通过,表示这期间确实没有写操作,数据可以安全使用,如果校验没通过,需要重新获取读锁,保证数据安全。
            long stamp = lock.tryOptimisticRead();
            log.debug("optimistic read locking...{}", stamp);
            sleep(readTime);
            if (lock.validate(stamp)) {
                log.debug("read finish...{}, data:{}", stamp, data);
                return data;
            }
            // 锁升级 - 读锁
            log.debug("updating to read lock... {}", stamp);
            try {
                stamp = lock.readLock();
                log.debug("read lock {}", stamp);
                sleep(readTime);
                log.debug("read finish...{}, data:{}", stamp, data);
                return data;
            } finally {
                log.debug("read unlock {}", stamp);
                lock.unlockRead(stamp);
            }
        }
    
        public void write(int newData) {
            long stamp = lock.writeLock();
            log.debug("write lock {}", stamp);
            try {
                sleep(2);
                this.data = newData;
            } finally {
                log.debug("write unlock {}", stamp);
                lock.unlockWrite(stamp);
            }
        }
    }
    

    7.3.4 Semaphore(信号量)

    信号量,用来限制能同时访问共享资源的线程上限。

    public class TestSemaphore {
        public static void main(String[] args) {
            // 1. 创建 semaphore 对象
            Semaphore semaphore = new Semaphore(3);
    
            // 2. 10个线程同时运行
            for (int i = 0; i < 10; i++) {
                new Thread(() -> {
                    try {
                        semaphore.acquire();
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                    try {
                        log.debug("running...");
                        sleep(1);
                        log.debug("end...");
                    } finally {
                        semaphore.release();
                    }
                }).start();
            }
        }
    }
    

    应用:限制对共享资源的使用

    使用 Semaphore 限流,在访问高峰期时,让请求线程阻塞,高峰期过去再释放许可,当然它只适合限制单机 线程数量,并且仅是限制线程数,而不是限制资源数(例如连接数,请对比 Tomcat LimitLatch 的实现)。它适用于资源数=线程数的场景,例如:连接池

    注:由于Tomcat使用的是nio来接收请求的,所以在连接器部分只有1个接收线程的事件循环组和处理事件的事件循环组,只有2个线程,无法使用 Semaphore。

    public class TestPoolSemaphore {
        public static void main(String[] args) {
            Pool pool = new Pool(2);
            for (int i = 0; i < 5; i++) {
                new Thread(() -> {
                    Connection conn = pool.borrow();
                    try {
                        Thread.sleep(1000);
                    } catch (InterruptedException e) {
                        e.printStackTrace();
                    }
                    pool.free(conn);
                }).start();
            }
        }
    }
    
    @Slf4j(topic = "c.Pool")
    class Pool {
        // 1. 连接池大小
        private final int poolSize;
    
        // 2. 连接对象数组
        private Connection[] connections;
    
        // 3. 连接状态数组 0 表示空闲, 1 表示繁忙
        private AtomicIntegerArray states;
    
        private Semaphore semaphore;
    
        // 4. 构造方法初始化
        public Pool(int poolSize) {
            this.poolSize = poolSize;
            // 让许可数与资源数一致
            this.semaphore = new Semaphore(poolSize);
            this.connections = new Connection[poolSize];
            this.states = new AtomicIntegerArray(new int[poolSize]);
            for (int i = 0; i < poolSize; i++) {
                connections[i] = new MockConnection("连接" + (i+1));
            }
        }
    
        // 5. 借连接
        public Connection borrow() {// t1, t2, t3
            // 获取许可
            try {
                semaphore.acquire(); // 没有许可的线程,在此等待
            } catch (InterruptedException e) {
                e.printStackTrace();
            }
            for (int i = 0; i < poolSize; i++) {
                // 获取空闲连接
                if(states.get(i) == 0) {
                    if (states.compareAndSet(i, 0, 1)) {
                        log.debug("borrow {}", connections[i]);
                        return connections[i];
                    }
                }
            }
            // 不会执行到这里
            return null;
        }
        // 6. 归还连接
        public void free(Connection conn) {
            for (int i = 0; i < poolSize; i++) {
                if (connections[i] == conn) {
                    states.set(i, 0);
                    log.debug("free {}", conn);
                    semaphore.release();
                    break;
                }
            }
        }
    }
    

    原理

    Semaphore 有点像一个停车场,permits 就好像停车位数量,当线程获得了 permits 就像是获得了停车位,然后 停车场显示空余车位减一

    刚开始,permits(state)为 3,这时 5 个线程来获取资源

    image

    假设其中 Thread-1,Thread-2,Thread-4 cas 竞争成功,而 Thread-0 和 Thread-3 竞争失败,进入 AQS 队列 park 阻塞

    image

    这时 Thread-4 释放了 permits,状态如下

    image

    接下来 Thread-0 竞争成功,permits 再次设置为 0,设置自己为 head 节点,断开原来的 head 节点,unpark 接下来的 Thread-3 节点,但由于 permits 是 0,因此 Thread-3 在尝试不成功后再次进入 park 状态

    image
    static final class NonfairSync extends Sync {
        private static final long serialVersionUID = -2694183684443567898L;
    
        NonfairSync(int permits) { // permits 即 state
            super(permits);
        }
    
        // Semaphore 方法, 方便阅读, 放在此处
        public void acquire() throws InterruptedException {
            sync.acquireSharedInterruptibly(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final void acquireSharedInterruptibly(int arg)
                throws InterruptedException {
            if (Thread.interrupted())
                throw new InterruptedException();
            // 尝试获取锁,返回-1则证明锁全被人占了
            if (tryAcquireShared(arg) < 0)
                doAcquireSharedInterruptibly(arg);
        }
    
        // 尝试获得共享锁
        protected int tryAcquireShared(int acquires) {
            return nonfairTryAcquireShared(acquires);
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        final int nonfairTryAcquireShared(int acquires) {
            for (; ; ) {
                int available = getState();
                int remaining = available - acquires;
                if (
                        // 如果许可已经用完, 返回负数, 表示获取失败, 进入 doAcquireSharedInterruptibly
                        remaining < 0 ||
                                // 如果 cas 重试成功, 返回正数, 表示获取成功
                                compareAndSetState(available, remaining)
                        ) {
                    return remaining;
                }
            }
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        private void doAcquireSharedInterruptibly(int arg) throws InterruptedException {
            final Node node = addWaiter(Node.SHARED);
            boolean failed = true;
            try {
                for (; ; ) {
                    final Node p = node.predecessor();
                    if (p == head) {
                        // 再次尝试获取许可
                        int r = tryAcquireShared(arg);
                        if (r >= 0) {
                            // 成功后本线程出队(AQS), 所在 Node设置为 head
                            // 如果 head.waitStatus == Node.SIGNAL ==> 0 成功, 下一个节点 unpark
                            // 如果 head.waitStatus == 0 ==> Node.PROPAGATE
                            // r 表示可用资源数, 为 0 则不会继续传播
                            setHeadAndPropagate(node, r);
                            p.next = null; // help GC
                            failed = false;
                            return;
                        }
                    }
                    // 不成功, 设置上一个节点 waitStatus = Node.SIGNAL, 下轮进入 park 阻塞
                    if (shouldParkAfterFailedAcquire(p, node) &&
                            parkAndCheckInterrupt())
                        throw new InterruptedException();
                }
            } finally {
                if (failed) cancelAcquire(node);
            }
        }
    
        // Semaphore 方法, 方便阅读, 放在此处
        public void release() {
            sync.releaseShared(1);
        }
    
        // AQS 继承过来的方法, 方便阅读, 放在此处
        public final boolean releaseShared(int arg) {
            if (tryReleaseShared(arg)) {
                // 唤醒等待的线程
                doReleaseShared();
                return true;
            }
            return false;
        }
    
        // Sync 继承过来的方法, 方便阅读, 放在此处
        protected final boolean tryReleaseShared(int releases) {
            for (; ; ) {
                int current = getState();
                int next = current + releases;
                if (next < current) // overflow
                    throw new Error("Maximum permit count exceeded");
                if (compareAndSetState(current, next)) {
                    return true;
                }
            }
        }
    }
    
    为什么要有 PROPAGATE

    7.3.5 CountdownLatch

    用来进行线程同步协作,等待所有线程完成倒计时。

    其中构造参数用来初始化等待计数值,await() 用来等待计数归零,countDown() 用来让计数减一

    public class CountDownLatchDemo {
    
        public static void main(String[] args) {
    
            CountDownLatch countDownLatch = new CountDownLatch(4);
    
            for (int i = 0; i < 4; i++) {
                new Thread(() -> {
                    System.out.println(Thread.currentThread().getName() + "天,过去了");
                    // 做完事情,拿下一把锁
                    countDownLatch.countDown();
                }, Objects.requireNonNull(SeasonEnum.getSeasonDesc(i))).start();
            }
    
            try {
                countDownLatch.await();
                System.out.println(Thread.currentThread().getName() + "新的一年开始了!");
            } catch (InterruptedException e) {
                e.printStackTrace();
            }
    
        }
    
    }
    
    // 可以通过枚举将代码解耦,这样如果要改的时候,只需要更改枚举中的内容就行了
    
    public enum SeasonEnum {
    
        Spring(0, "春"),
        Summer(1, "夏"),
        Autumn(2, "秋"),
        Winter(3, "冬"),
        ;
    
        private Integer code;
        private String desc;
    
        SeasonEnum(Integer code, String desc) {
            this.code = code;
            this.desc = desc;
        }
    
        public Integer getCode() {
            return code;
        }
    
        public String getDesc() {
            return desc;
        }
    
        public static String getSeasonDesc(Integer code) {
            for (SeasonEnum seasonEnum : SeasonEnum.values()) {
                if (Objects.equals(seasonEnum.code, code)){
                    return seasonEnum.desc;
                }
            }
            return null;
        }
    }
    

    相较于join方法的好处?

    工作中我们不会自己创建线程的,都会用线程池的。

    CountDownLatch 的同步器代码

    private static final class Sync extends AbstractQueuedSynchronizer {
        private static final long serialVersionUID = 4982264981922014374L;
    
        // 初始化时将state设置为 count
        Sync(int count) {
            setState(count);
        }
    
        int getCount() {
            return getState();
        }
    
        // 尝试着获取锁(await方法调用),只有state为0时结束阻塞
        protected int tryAcquireShared(int acquires) {
            return (getState() == 0) ? 1 : -1;
        }
    
        // 尝试释放锁(countDown方法调用)
        protected boolean tryReleaseShared(int releases) {
            // Decrement count; signal when transition to zero
            for (;;) {
                int c = getState();
                if (c == 0)
                    return false;
                int nextc = c-1;
                if (compareAndSetState(c, nextc))
                    return nextc == 0;
            }
        }
    }
    

    7.3.6 CyclicBarrier

    循环栅栏,用来进行线程协作,等待线程满足某个计数。构造时设置『计数个数』,每个线程执行到某个需要“同步”的时刻调用 await() 方法进行等待,当等待的线程数满足『计数个数』时,继续执行。

    public static void main(String[] args) {
        // 注意:因为有循环,所以线程池的大小要设置为2,否则会有2个task1执行完调用回调,这种情况
        ExecutorService service = Executors.newFixedThreadPool(2);
        CyclicBarrier barrier = new CyclicBarrier(2, ()-> {
            log.debug("task1, task2 finish...");
        });
        for (int i = 0; i < 3; i++) {
            service.submit(() -> {
                log.debug("task1 begin...");
                try {
                    sleep(1);
                } catch (InterruptedException e) {
                    e.printStackTrace();
                }
                try {
                    barrier.await(); // 2-1=1
                } catch (InterruptedException | BrokenBarrierException e) {
                    e.printStackTrace();
                }
                log.error("1111");
            });
            service.submit(() -> {
                log.debug("task2 begin...");
                try {
                    sleep(2);
                } catch (InterruptedException e) {
                    e.printStackTrace();
                }
                try {
                    barrier.await(); // 1-1=0
                } catch (InterruptedException | BrokenBarrierException e) {
                    e.printStackTrace();
                }
            });
        }
        service.shutdown();
    
    }
    

    CyclicBarrier 与 CountDownLatch 的主要区别在于 CyclicBarrier 是可以重用的 CyclicBarrier 可以被比喻为『人满发车』;另一个区别就是 CyclicBarrier 的await方法会阻塞线程,直到所有线程都调用await方法后执行完回调,才会向下执行。

    相关文章

      网友评论

        本文标题:并发总结(中)

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