Netty源码—10.Netty工具之时间轮一

news2025/4/3 17:17:38

大纲

1.什么是时间轮

2.HashedWheelTimer是什么

3.HashedWheelTimer的使用

4.HashedWheelTimer的运行流程

5.HashedWheelTimer的核心字段

6.HashedWheelTimer的构造方法

7.HashedWheelTimer添加任务和执行任务

8.HashedWheelTimer的完整源码

9.HashedWheelTimer的总结

10.HashedWheelTimer的应用

1.什么是时间轮

简单来说,时间轮是一个高效利用线程资源进行批量化调度的调度器。首先把大批量的调度任务全部绑定到同一个调度器上,然后使用这个调度器对所有任务进行管理、触发、以及运行,所以时间轮能高效管理各种延时任务、周期任务、通知任务。

时间轮是以时间作为刻度组成的一个环形队列,所以叫做时间轮。这个环形队列通过一个HashedWheelBucket[]数组来实现,数组的每个元素称为槽,每个槽可以存放一个定时任务列表,叫HashedWheelBucket。HashedWheelBucket是一个双向链表,链表的每个节点表示一个定时任务项HashedWheelTimeout。在HashedWheelTimeout中封装了真正的定时任务TimerTask。

时间轮由多个时间格组成,每个时间格代表当前时间轮的基本时间跨度ticketDuration,其中时间轮的时间格的个数是固定的。

如下图示,有16个时间格(槽),假设每个时间格的单位是1s,那么整个时间轮走完一圈需要16s。每秒钟(即时间格的单位也可以为1ms、1min、1h等)指针会沿着顺时针方向转动一格。通过指针移动来获得每个时间格中的任务列表,然后遍历这个时间格内的双向链表的每个任务并执行,依此循环。

图片

2.HashedWheelTimer是什么

Netty的HashedWheelTimer是一个粗略的定时器实现,之所以称为粗略的实现是因为该时间轮并没有严格准时地执行定时任务,而是在每隔一个时间间隔之后的时间节点执行,并执行当前时间节点之前到期的定时任务。

不过具体的定时任务的时间执行精度,可以通过调节HashedWheelTimer构造方法的时间间隔的大小来进行调节。在大多数网络应用的情况下,由于IO延迟的存在,所以并不会严格要求具体的时间执行精度。因此默认100ms的时间间隔可以满足大多数情况,不需要再花精力去调节该时间精度。

3.HashedWheelTimer的使用

public class HashedWheelTimerTest {
    //构建HashedWheelTimer时间轮
    //最后通过HASHED_WHEEL_TIMER.newTimeout()方法把需要延迟执行的任务添加到时间轮中
    private static final HashedWheelTimer HASHED_WHEEL_TIMER = new HashedWheelTimer(
        new DefaultThreadFactory("demo-timer"),//threadFactory参数表示创建处理任务的线程工厂
        100,//tickDuration参数表示每个时间格代表当前时间轮的基本时间跨度,这里是100ms,也就是指针100ms跳动一次,每次跳动一个窗格 
        TimeUnit.MILLISECONDS,
        512,//ticksPerWheel参数表示时间轮上一共有多少个时间格,分配的时间格越多,占用内存空间就越大,这里是512
        true//leakDetection参数表示是否开启内存泄漏检测
    );

    public static void main(String[] args) {
        System.out.println("延时任务提交");
        //延时多久执行
        long delay = 10L;
        HASHED_WHEEL_TIMER.newTimeout(new TimerTask() {
            @Override
            public void run(Timeout timeout) throws Exception {
                System.out.println("延时任务触发");
            }
        }, delay, TimeUnit.SECONDS);
    }
}

4.HashedWheelTimer的运行流程

步骤一:初始化时间轮

步骤二:启动时间轮

步骤三:添加任务,保存到延时任务队列

步骤四:时间轮指针休眠阻塞,实现转动

步骤五:休眠结束,指针指向下一个时间格(槽)

步骤六:将已经取消的任务从对应的槽中移除

步骤七:将延时任务队列的任务添加到对应的槽中

步骤八:执行时间轮指针指向当前槽的到期任务

图片

5.HashedWheelTimer中的关键字段

字段一:wheel

wheel是一个HashedWheelBucket数组,默认的数组大小是512。可以认为wheel是一个TimerTask的哈希表,它的哈希函数是任务的截止日期。所以每个时间轮的时间格数ticksPerWheel默认是512。

字段二:tickDuration

时间格跨度,默认100ms。

字段三:ticksPerWheel

时间轮的格子数,默认512。

字段四:maxPendingTimeouts

时间轮中任务的最大数量。

字段五:deadline

延时任务的截止时间,值为当前时间 + 延时任务的延时时间 - 时间轮启动时间。

字段六:tick

时间轮启动以来指针总的转动次数。

字段七:remainingRounds

槽中延时任务剩余的圈(轮)数,为0时则表示需要执行延时任务了。

6.HashedWheelTimer的构造方法

步骤一:构造参数校验及给实际执行延时任务的线程池taskExecutor赋值

步骤二:将ticksPerWheel(时间轮上的时间格数)向上取值为2的幂

步骤三:初始化HashedWheelBucket数组wheel

步骤四:校验tickDuration和ticksPerWheel

步骤五:创建工作线程workerThread,用于指针转动和触发执行时间格里的延时任务

步骤六:给时间轮中延时任务的最大数量maxPendingTimeouts赋值

步骤七:检查HashedWheelTimer的实例数量,如果大于64则打印error日志

图片

//4.1.73.Final
public class HashedWheelTimer implements Timer {
    private final HashedWheelBucket[] wheel;
    private final int mask;
    private final long tickDuration;
    private final Thread workerThread;
    private final ResourceLeakTracker<HashedWheelTimer> leak;
    private final Worker worker = new Worker();
    private final long maxPendingTimeouts;
    private final Executor taskExecutor;
    ...
    //Creates a new timer.
    //@param threadFactory        创建线程的工厂
    //@param tickDuration         每格的时间间隔,默认100ms,0.1秒
    //@param unit                 时间单位,默认为毫秒
    //@param ticksPerWheel        时间轮的格子数,默认为512;如果传入的不是2的N次方,则会调整为大于等于该参数的第一个2的N次方,好处是可以优化hash值的计算 
    //@param leakDetection        如果false,那么只有工作线程不是后台线程时才会追踪资源泄露,这个参数可以忽略
    //@param maxPendingTimeouts   最大的pending数量(时间轮中任务的最大数量),超过这个值之后调用将抛出异常,0或者负数表示没有限制,默认为-1
    //@param taskExecutor         任务线程池,用于执行提交的任务,调用者负责在不需要时关闭它
    //@throws NullPointerException     if either of threadFactory and unit is null
    //@throws IllegalArgumentException if either of tickDuration and ticksPerWheel is <= 0
    public HashedWheelTimer(ThreadFactory threadFactory, long tickDuration, TimeUnit unit, int ticksPerWheel, boolean leakDetection, long maxPendingTimeouts, Executor taskExecutor) { 
        //1.构造参数校验及给实际执行延时任务的线程池taskExecutor赋值
        checkNotNull(threadFactory, "threadFactory");
        checkNotNull(unit, "unit");
        checkPositive(tickDuration, "tickDuration");
        checkPositive(ticksPerWheel, "ticksPerWheel");
        this.taskExecutor = checkNotNull(taskExecutor, "taskExecutor");

        //2.将ticksPerWheel(时间轮上的时间格数)向上取值为2的幂,方便进行求商和取余计算
        //3.初始化时间轮wheel
        wheel = createWheel(ticksPerWheel);
        //mask的设计和HashMap一样,通过限制数组的大小为2的幂,利用位运算来替代取模运算,提高性能
        mask = wheel.length - 1;
      
        //4.校验tickDuration和ticksPerWheel
        //Convert tickDuration to nanos.
        long duration = unit.toNanos(tickDuration);
        //防止溢出
        //tickDuration * ticksPerWheel必须小于Long.MAX_VALUE
        if (duration >= Long.MAX_VALUE / wheel.length) {
            throw new IllegalArgumentException(String.format("tickDuration: %d (expected: 0 < tickDuration in nanos < %d", tickDuration, Long.MAX_VALUE / wheel.length));
        }
        //tickDuration不能小于1ms
        if (duration < MILLISECOND_NANOS) {
            logger.warn("Configured tickDuration {} smaller then {}, using 1ms.", tickDuration, MILLISECOND_NANOS);
            this.tickDuration = MILLISECOND_NANOS;
        } else {
            this.tickDuration = duration;
        }
        //5.创建工作线程,用于指针转动和触发时间格里的延时任务的执行
        workerThread = threadFactory.newThread(worker);

        leak = leakDetection || !workerThread.isDaemon() ? leakDetector.track(this) : null;
        //6.给时间轮中任务的最大数量maxPendingTimeouts赋值
        this.maxPendingTimeouts = maxPendingTimeouts;
        //7.检查HashedWheelTimer的实例数量,如果大于64则打印error日志
        if (INSTANCE_COUNTER.incrementAndGet() > INSTANCE_COUNT_LIMIT &&
            WARNED_TOO_MANY_INSTANCES.compareAndSet(false, true)) {
            reportTooManyInstances();
        }
    }
    
    //初始化时间轮环形数组
    //@param ticksPerWheel
    private static HashedWheelBucket[] createWheel(int ticksPerWheel) {
        //ticksPerWheel不能大于2^30
        checkInRange(ticksPerWheel, 1, 1073741824, "ticksPerWheel");
        //将ticksPerWheel(轮子上的时间格数)向上取值为2的次幂
        ticksPerWheel = normalizeTicksPerWheel(ticksPerWheel);
        //创建时间轮环形数组
        HashedWheelBucket[] wheel = new HashedWheelBucket[ticksPerWheel];
        for (int i = 0; i < wheel.length; i ++) {
            wheel[i] = new HashedWheelBucket();
        }
        return wheel;
    }
    ...
}

7.HashedWheelTimer添加任务和执行任务

(1)添加延时任务

(2)执行延时任务

(1)添加延时任务

步骤一:将需要执行的延时任务数pendingTimeouts+1

步骤二:如果pendingTimeouts超过maxPendingTimeouts,则抛出异常

步骤三:启动工作线程,也就是启动时间轮

步骤四:计算被添加的延时任务的截止时间=当前时间+当前任务执行的延迟时间-时间轮启动的时间

步骤五:创建延时任务实例HashedWheelTimeout

步骤六:将延时任务实例添加到延时任务队列timeouts中

图片

注意:添加时会将延时任务添加到延时任务队列timeouts中。这个延时任务队列timeouts将会在下一个滴答声中进行处理(指针的下一次转动)。在处理过程中,所有排队的HashedWheelTimeout将被添加到正确的HashedWheelBucket。

public class HashedWheelTimer implements Timer {
    private final AtomicLong pendingTimeouts = new AtomicLong(0);//需要执行的延时任务数
    private final long maxPendingTimeouts;
    private volatile long startTime;
    private final CountDownLatch startTimeInitialized = new CountDownLatch(1);
    private final Queue<HashedWheelTimeout> timeouts = PlatformDependent.newMpscQueue();//延时任务队列
    ...
    //添加延时任务
    //@param task 任务
    //@param delay 延时时间
    //@param unit 延时时间单位
    @Override
    public Timeout newTimeout(TimerTask task, long delay, TimeUnit unit) {
        checkNotNull(task, "task");
        checkNotNull(unit, "unit");
        //1.将需要执行的延时任务数pendingTimeouts + 1
        long pendingTimeoutsCount = pendingTimeouts.incrementAndGet();
       
        //2.如果pendingTimeouts超过maxPendingTimeouts,则抛出异常
        if (maxPendingTimeouts > 0 && pendingTimeoutsCount > maxPendingTimeouts) {
            pendingTimeouts.decrementAndGet();
            throw new RejectedExecutionException("Number of pending timeouts (" + pendingTimeoutsCount 
                + ") is greater than or equal to maximum allowed pending " + "timeouts (" + maxPendingTimeouts + ")"); 
        }
      
        //3.启动工作线程,即启动时间轮
        start();
     
        //将延时任务添加到延时任务队列timeouts中,该队列将在下一个滴答声中处理(指针的下一次转动)
        //在处理过程中,所有排队的HashedWheelTimeout将被添加到正确的HashedWheelBucket

        //4.计算任务的截止时间deadline = 当前时间 + 当前任务执行的延迟时间 - 时间轮启动的时间
        long deadline = System.nanoTime() + unit.toNanos(delay) - startTime;
        if (delay > 0 && deadline < 0) {
            deadline = Long.MAX_VALUE;
        }
       
        //5.创建延时任务实例HashedWheelTimeout
        HashedWheelTimeout timeout = new HashedWheelTimeout(this, task, deadline);
       
        //6.将延时任务实例添加到延时任务队列中
        timeouts.add(timeout);
        return timeout;
    }
    
    //Starts the background thread explicitly.  
    //The background thread will start automatically on demand even if you did not call this method.
    //@throws IllegalStateException if this timer has been #stop() stopped already
    public void start() {
        switch (WORKER_STATE_UPDATER.get(this)) {
        case WORKER_STATE_INIT:
            if (WORKER_STATE_UPDATER.compareAndSet(this, WORKER_STATE_INIT, WORKER_STATE_STARTED)) {
                //启动工作线程,即启动时间轮
                workerThread.start();
            }
            break;
        case WORKER_STATE_STARTED:
            break;
        case WORKER_STATE_SHUTDOWN:
            throw new IllegalStateException("cannot be started once stopped");
        default:
            throw new Error("Invalid WorkerState");
        }

        //Wait until the startTime is initialized by the worker.
        while (startTime == 0) {
            try {
                //阻塞时间轮的工作线程
                startTimeInitialized.await();
            } catch (InterruptedException ignore) {
                //Ignore - it will be ready very soon.
            }
        }
    }
    ...
}

(2)执行延时任务

步骤一:记录时间轮启动的时间startTime

步骤二:开始do while循环,唤醒被阻塞的start()方法,通知时间轮已经启动完毕

步骤三:阻塞等待下一次指针转动的时间

步骤四:计算当前指针指向的时间轮的槽位idx

步骤五:将已经取消的任务从HashedWheelBucket数组中移除,并将pendingTimeouts任务数 - 1

步骤六:获取当前指针指向的时间槽HashedWheelBucket

步骤七:遍历延时任务队列timeouts,将其中的延时任务保存到对应的槽的链表中,根据延时时间计算对应的时间槽和remainingRounds圈数

步骤八:运行目前指针指向的时间槽中的链表的任务,通过taskExecutor线程池去执行到期的任务

步骤九:到期的和取消的延时任务从链表中移除并将pendingTimeouts--

步骤十:时间轮指针的总转动次数tick++,继续do while循环

步骤十一:清除时间轮中不需要处理的任务,保存到unprocessedTimeouts中

步骤十二:将延时任务队列中还未添加到时间轮的延时任务保存到unprocessedTimeouts中

步骤十三:将已经取消的任务从HashedWheelBucket数组中移除,并将pendingTimeouts任务数 - 1

public class HashedWheelTimer implements Timer {
    private volatile long startTime;
    private final CountDownLatch startTimeInitialized = new CountDownLatch(1);
    
    ...
    //指针转动和执行延时任务的线程
    private final class Worker implements Runnable {
        //用于记录未执行的延时任务
        private final Set<Timeout> unprocessedTimeouts = new HashSet<Timeout>();
    
        //总的tick数(指针嘀嗒的次数)
        private long tick;
    
        @Override
        public void run() {
            //1.记录时间轮启动的时间startTime
            startTime = System.nanoTime();
            if (startTime == 0) {
                //我们在这里使用0作为未初始化值的指示符,所以要确保初始化时它不是0
                startTime = 1;
            }
    
            //2.唤醒被阻塞的start()方法,通知时间轮已经启动完毕
            startTimeInitialized.countDown();
        
            //一直执行do while循环,直到时间轮被关闭
            do {
                //3.阻塞等待下一次指针转动的时间
                //这里会休眠tick的时间,模拟指针走动
                final long deadline = waitForNextTick();
                if (deadline > 0) {
                    //4.计算当前指针指向的时间轮槽位idx
                    int idx = (int) (tick & mask);
                    //5.将已经取消的任务从HashedWheelBucket数组中移除,并将pendingTimeouts任务数 - 1
                    processCancelledTasks();
                    //6.获取当前指针指向的时间槽HashedWheelBucket
                    HashedWheelBucket bucket = wheel[idx];
                    //7.遍历延时任务队列timeouts,将其中的延时任务保存到对应的槽的链表中
                    transferTimeoutsToBuckets();
                    //8.运行目前指针指向的槽中的链表的任务,交给taskExecutor线程池去执行到期的延时任务
                    //9.到期的和取消的延时任务从链表中移除并将pendingTimeouts--
                    bucket.expireTimeouts(deadline);
                    //10.时间轮指针的总转动次数tick++
                    tick++;
                }
            } while (WORKER_STATE_UPDATER.get(HashedWheelTimer.this) == WORKER_STATE_STARTED);
    
            //Fill the unprocessedTimeouts so we can return them from stop() method.
            //11.清除时间轮中不需要处理的任务
            for (HashedWheelBucket bucket: wheel) {
                bucket.clearTimeouts(unprocessedTimeouts);
            }
            //12.将延时任务队列中还未添加到时间轮的延时任务保存到unprocessedTimeouts中
            //遍历任务队列,如果发现有任务被取消,则添加到unprocessedTimeouts,也就是不需要处理的队列中
            for (;;) {
                HashedWheelTimeout timeout = timeouts.poll();
                if (timeout == null) {
                    break;
                }
                if (!timeout.isCancelled()) {
                    //如果延时任务没被取消,记录到未执行的任务Set集合中
                    unprocessedTimeouts.add(timeout);
                }
            }
            //13.处理被取消的任务
            processCancelledTasks();
        }
    
        //将延时任务队列timeouts中等待添加到时间轮中的延时任务,转移到时间轮的指定位置
        //也就是遍历延时任务队列timeouts,将其中的延时任务保存到对应的槽的链表中
        private void transferTimeoutsToBuckets() {
            //每次转移10w个延时任务
            for (int i = 0; i < 100000; i++) {
                //从队列中出队一个延时任务
                HashedWheelTimeout timeout = timeouts.poll();
                if (timeout == null) {
                    //all processed
                    break;
                }
                if (timeout.state() == HashedWheelTimeout.ST_CANCELLED) {
                    //Was cancelled in the meantime.
                    continue;
                }
                //到期一共需要走多少时间格(tick次数),deadline表示当前任务的延迟时间(从时间轮启动时计算),tickDuration表示时间格的时间间隔 
                long calculated = timeout.deadline / tickDuration;
                //tick已经走了的时间格,到期一共还需要需要走多少圈
                timeout.remainingRounds = (calculated - tick) / wheel.length;
                //如果延时任务在队列中等待太久已经过了执行时间,那么这个时候就使用当前tick,也就是放在当前的bucket,此方法调用完后就会被执行
                final long ticks = Math.max(calculated, tick);
                //槽的索引,stopIndex = tick 次数 & mask, mask = wheel.length - 1
                int stopIndex = (int) (ticks & mask);
                //根据索引该任务应该放到的槽
                HashedWheelBucket bucket = wheel[stopIndex];
                //将任务添加到槽中,链表末尾
                bucket.addTimeout(timeout);
            }
        }
    
        //处理取消掉的延时任务
        //将已经取消的任务从HashedWheelBucket数组中移除,并将pendingTimeouts任务数 - 1
        private void processCancelledTasks() {
            for (;;) {
                HashedWheelTimeout timeout = cancelledTimeouts.poll();
                if (timeout == null) {
                    //all processed
                    break;
                }
                try {
                    timeout.remove();
                } catch (Throwable t) {
                    if (logger.isWarnEnabled()) {
                        logger.warn("An exception was thrown while process a cancellation task", t);
                    }
                }
            }
        }
    
        //从时间轮的启动时间startTime和当前的tick数(指针跳动次数)计算下一次指针跳动的时间,然后休眠等待下一次指针跳动时间到来
        private long waitForNextTick() {
            //deadline返回的是下一次时间轮指针跳动的时间与时间格启动的时间间隔
            long deadline = tickDuration * (tick + 1);
    
            for (;;) {
                //计算当前时间距离启动时间的时间间隔
                final long currentTime = System.nanoTime() - startTime;
                //距离下一次指针跳动还需休眠多长时间
                long sleepTimeMs = (deadline - currentTime + 999999) / 1000000;
                //到了指针调到下一个槽位的时间
                if (sleepTimeMs <= 0) {
                    if (currentTime == Long.MIN_VALUE) {
                        return -Long.MAX_VALUE;
                    } else {
                        return currentTime;
                    }
                }
    
                try {
                    //表示距离下一次指针跳动还需要一段时间,所以休眠等待时间的到来
                    Thread.sleep(sleepTimeMs);
                } catch (InterruptedException ignored) {
                    if (WORKER_STATE_UPDATER.get(HashedWheelTimer.this) == WORKER_STATE_SHUTDOWN) {
                        return Long.MIN_VALUE;
                    }
                }
            }
        }
    
        //记录未执行的延时任务
        public Set<Timeout> unprocessedTimeouts() {
            return Collections.unmodifiableSet(unprocessedTimeouts);
        }
    }
    
    private static final class HashedWheelBucket {
        ...
        public void expireTimeouts(long deadline) {
            HashedWheelTimeout timeout = head;
        
            //process all timeouts
            while (timeout != null) {
                HashedWheelTimeout next = timeout.next;
                if (timeout.remainingRounds <= 0) {
                    next = remove(timeout);
                    if (timeout.deadline <= deadline) {
                        //通过线程池执行任务
                        timeout.expire();
                    } else {
                        //The timeout was placed into a wrong slot. This should never happen.
                        throw new IllegalStateException(String.format("timeout.deadline (%d) > deadline (%d)", timeout.deadline, deadline)); 
                    }
                } else if (timeout.isCancelled()) {
                    next = remove(timeout);
                } else {
                    timeout.remainingRounds --;
                }
                timeout = next;
            }
        }

        public HashedWheelTimeout remove(HashedWheelTimeout timeout) {
            HashedWheelTimeout next = timeout.next;
            //remove timeout that was either processed or cancelled by updating the linked-list
            if (timeout.prev != null) {
                timeout.prev.next = next;
            }
            if (timeout.next != null) {
                timeout.next.prev = timeout.prev;
            }

            if (timeout == head) {
                //if timeout is also the tail we need to adjust the entry too
                if (timeout == tail) {
                    tail = null;
                    head = null;
                } else {
                    head = next;
                }
            } else if (timeout == tail) {
                //if the timeout is the tail modify the tail to be the prev node.
                tail = timeout.prev;
            }
            //null out prev, next and bucket to allow for GC.
            timeout.prev = null;
            timeout.next = null;
            timeout.bucket = null;
            timeout.timer.pendingTimeouts.decrementAndGet();
            return next;
        }
        ...    
    }
    
    private static final class HashedWheelTimeout implements Timeout, Runnable {
        private final TimerTask task;
        private final HashedWheelTimer timer;
        ...
        public void expire() {
            if (!compareAndSetState(ST_INIT, ST_EXPIRED)) {
                return;
            }
            try {
                timer.taskExecutor.execute(this);
            } catch (Throwable t) {
                if (logger.isWarnEnabled()) {
                    logger.warn("An exception was thrown while submit " + TimerTask.class.getSimpleName() + " for execution.", t);
                }
            }
        }
        ...
    }
    ...
}

本文来自互联网用户投稿,该文观点仅代表作者本人,不代表本站立场。本站仅提供信息存储空间服务,不拥有所有权,不承担相关法律责任。如若转载,请注明出处:http://www.coloradmin.cn/o/2327366.html

如若内容造成侵权/违法违规/事实不符,请联系多彩编程网进行投诉反馈,一经查实,立即删除!

相关文章

鸿蒙项目笔记(1)

一、核心内容-商城 1、装饰器的拓展使用&#xff0c;基础组件的熟悉。 2、引入基础动画实战&#xff0c;页面属性动画、页面跳转动画、自定义页面翻页等。 3、一次开发&#xff0c;多端部署。 4、本地数据库实战&#xff0c;涉及多种本地数据存储方式。 5、路由导航&#…

*快排延伸-自省排序

此节是学有余力的人去看&#xff0c;如果没时间&#xff0c;不看也没关系&#xff0c;只要知道代码就可以了&#xff01; 自省排序的思路是自我侦测和反省&#xff0c;快速排序如果递归深度太深&#xff0c;其算法的效率可能被大幅度削弱&#xff0c;这就需要借助其他的算法进…

三.微服务架构中的精妙设计:服务注册/服务发现-Eureka

一.使用注册中心背景 1.1服务远程调用问题 服务之间远程调⽤时, 我们的URL是写死的 String url "http://127.0.0.1:9090/product/" orderInfo.getProductId(); 缺点&#xff1a; 当更换机器, 或者新增机器时, 这个URL就需要跟着变更, 就需要去通知所有的相关服…

python-leetcode 63.搜索二维矩阵

题目&#xff1a; 给一个满足两条属性的m*n的整数矩阵&#xff1a; 每行中的整数从左到右按非严格递增顺序排列 每行的第一个整数大于前一行的最后一个整数 给一个整数target,如果target在矩阵中&#xff0c;返回true,否则返回false 方法一&#xff1a;两次二分查找 由于每…

音视频入门基础:MPEG2-TS专题(26)——通过FFmpeg命令使用RTP发送TS流

音视频入门基础&#xff1a;MPEG2-TS专题系列文章&#xff1a; 音视频入门基础&#xff1a;MPEG2-TS专题&#xff08;1&#xff09;——MPEG2-TS官方文档下载 音视频入门基础&#xff1a;MPEG2-TS专题&#xff08;2&#xff09;——使用FFmpeg命令生成ts文件 音视频入门基础…

blender二次元上色

前&#xff1a; 后&#xff1a;&#xff08;脸自己会发光) 参考&#xff1a;05-模型导入与材质整理_哔哩哔哩_bilibili

2025年2月一区SCI-壮丽细尾鹩莺算法Superb Fairy-wren Optimization-附Matlab免费代码

引言 本期介绍一种新的元启发式算法——壮丽细尾鹩莺优化算法Superb Fairy-wren Optimization algorithm&#xff0c;SFOA。该算法结合了壮丽细尾鹩莺群体中幼鸟的发育&#xff0c;繁殖后喂养幼鸟的行为&#xff0c;以及它们躲避捕食者的策略&#xff0c;于2025年2月最新发表在…

Hadoop•踩过的SHIT

听说这里是目录哦 ssh登录Permission denied, please try again&#x1f4a9;要发癫&#x1f972; centos7 yum报错&#xff1a;cannot find a valid baseurl for repo:base/7/x86_64&#x1f4a9;FinalShell重连失效&#x1f4a9;ssh免密登录显示 No route to host&#x1f4a…

闭环SOTA!北航DiffAD:基于扩散模型实现端到端自动驾驶「多任务闭环统一」

端到端自动驾驶目前是有望实现完全自动驾驶的一条有前景的途径。然而&#xff0c;现有的端到端自动驾驶系统通常采用主干网络与多任务头结合的方式&#xff0c;但是它们存在任务协调和系统复杂度高的问题。为此&#xff0c;本文提出了DiffAD&#xff0c;它统一了各种驾驶目标并…

Docker Registry 清理镜像最佳实践

文章目录 registry-clean1. 简介2. 功能3. 安装 docker4. 配置 docker5. 配置域名解析6. 部署 registry7. Registry API 管理8. 批量清理镜像9. 其他10. 参考registry-clean 1. 简介 registry-clean 是一个强大而高效的解决方案,旨在简化您的 Docker 镜像仓库管理。通过 reg…

JavaScript重难点突破:期约与异步函数

同步和异步 ​同步&#xff08;Synchronous&#xff09;​ ​定义&#xff1a;任务按顺序依次执行&#xff0c;前一个任务完成前&#xff0c;后续任务必须等待。 ​特点&#xff1a;阻塞性执行&#xff0c;程序逻辑直观&#xff0c;但效率较低 ​异步&#xff08;Asynchron…

蓝桥杯高频考点——高精度(含C++源码)

高精度 前言高精度加法例题思路及代码solution 1&#xff08;初阶版 40分&#xff09;solution 2&#xff08;完全体 AC&#xff09; 高精度乘法例题思路及代码solution 1&#xff08;TLE 但是代码很清晰&#xff09;solution 1的问题solution 2&#xff08;优化 AC&#xff09…

【机器人】复现 GraspNet 端到端抓取点估计 | PyTorch2.3 | CUDA12.1

GraspNet是通用物体抓取的大规模基准的基线模型&#xff0c;值得学习和复现。 本文分享使用较新版本的PyTorch和CUDA&#xff0c;来搭建开发环境。 论文地址&#xff1a;GraspNet-1Billion: A Large-Scale Benchmark for General Object Grasping 开源地址&#xff1a;https:…

视频联网平台智慧运维系统:智能时代的城市视觉中枢

引言&#xff1a;破解视频运维的"帕累托困境" 在智慧城市与数字化转型浪潮中&#xff0c;全球视频监控设备保有量已突破10亿台&#xff0c;日均产生的视频数据量超过10万PB。然而&#xff0c;传统运维模式正面临三重困境&#xff1a; 海量设备管理失序&#xff1a;…

《网络管理》实践环节03:snmp服务器上对网络设备和服务器进行初步监控

兰生幽谷&#xff0c;不为莫服而不芳&#xff1b; 君子行义&#xff0c;不为莫知而止休。 应用拓扑图 3.0准备工作 所有Linux服务器上&#xff08;服务器和Agent端&#xff09;安装下列工具 yum -y install net-snmp net-snmp-utils 保证所有的HCL网络设备和服务器相互间能…

ubuntu中使用安卓模拟器

本文这里介绍 使用 android studio Emulator &#xff0c; 当然也有 Anbox (Lightweight)&#xff0c; Waydroid (Best for Full Android Experience), 首先确保自己安装了 android studio &#xff1b; sudo apt update sudo apt install openjdk-11-jdk sudo snap install…

py数据结构day3

思维导图&#xff1a; 代码1&#xff08;完成双向循环链表的判空、尾插、遍历、尾删&#xff09;&#xff1a; class Node:def __init__(self, data):self.data dataself.next Noneself.prev Noneclass DoubleCycleLink:def __init__(self):self.head Noneself.tail None…

STM32单片机入门学习——第8节: [3-4] 按键控制LED光敏传感器控制蜂鸣器

写这个文章是用来学习的,记录一下我的学习过程。希望我能一直坚持下去,我只是一个小白,只是想好好学习,我知道这会很难&#xff0c;但我还是想去做&#xff01; 本文写于&#xff1a;2025.04.02 STM32开发板学习——第8节: [3-4] 按键控制LED&光敏传感器控制蜂鸣器 前言开…

【JavaScript】十三、事件监听与事件类型

文章目录 1、事件监听1.1 案例&#xff1a;击关闭顶部广告1.2 案例&#xff1a;随机点名1.3 事件监听的版本 2、事件类型2.1 鼠标事件2.1.1 语法2.1.2 案例&#xff1a;轮播图主动切换 2.2 焦点事件2.2.1 语法2.2.2 案例&#xff1a;模拟小米搜索框 2.3 键盘事件2.3.1 语法2.3.…

通过ansible+docker-compose快速安装一主两从redis+三sentinel

目录 示例主机列表 架构参考 文件内容 安装脚本 ansible变量&#xff0c;需修改 ansible配置文件和主机清单&#xff0c;需修改 运行方式 验证故障转移master 涉及redis镜像和完整的脚本文件 示例主机列表 架构参考 文件内容 安装脚本 #!/bin/bashset -e export pa…