RocketMq刷盘机制

RocketMq刷盘机制

handleDiskFlush

public void handleDiskFlush(AppendMessageResult result, PutMessageResult putMessageResult, MessageExt messageExt) {
    // Synchronization flush 同步刷盘
    if (FlushDiskType.SYNC_FLUSH == this.defaultMessageStore.getMessageStoreConfig().getFlushDiskType()) {
      //① 同步刷盘使用GroupCommitService来刷盘
        final GroupCommitService service = (GroupCommitService) this.flushCommitLogService;
      //MessageConst.PROPERTY_WAIT_STORE_MSG_OK属性是否为true 默认Message构造中  都为true
      if (messageExt.isWaitStoreMsgOK()) {
        		//创建commit请求 将数据从mappedByteBuffer中刷盘到磁盘中
            GroupCommitRequest request = new GroupCommitRequest(result.getWroteOffset() + result.getWroteBytes());
            service.putRequest(request);
            //阻塞当前进程,等待刷盘完成或者5秒超时返回
            boolean flushOK =            request.waitForFlush(this.defaultMessageStore.getMessageStoreConfig().getSyncFlushTimeout());
            //如果刷盘失败打印日志
            if (!flushOK) {
                log.error("do groupcommit, wait for flush failed, topic: " + messageExt.getTopic() + " tags: " + messageExt.getTags()
                    + " client address: " + messageExt.getBornHostString());
                putMessageResult.setPutMessageStatus(PutMessageStatus.FLUSH_DISK_TIMEOUT);
            }
        } else {
            service.wakeup();
        }
    }
    // Asynchronous flush ②
    else {
        if (!this.defaultMessageStore.getMessageStoreConfig().isTransientStorePoolEnable()) {	
          //transientStorePoolEnable没有开启或者是从broker
            flushCommitLogService.wakeup();
        } else {
          //transientStorePoolEnable && FlushDiskType.ASYNC_FLUSH == getFlushDiskType() && BrokerRole.SLAVE != getBrokerRole() 开启transientStorePoolEnable,且刷盘模式是异步刷盘,且角色不说从broker
            commitLogService.wakeup();
        }
    }
}

①同步刷盘使用GroupCommitService

②异步刷盘 且开启了transientStorePoolEnable且不是从服务器,使用CommitLogService 否则使用FlushCommitLogService刷盘

GroupCommitService

public synchronized void putRequest(final GroupCommitRequest request) {
    synchronized (this.requestsWrite) {
        this.requestsWrite.add(request);
    }
    if (hasNotified.compareAndSet(false, true)) {
        waitPoint.countDown(); // notify
    }
}

putRequest 提交刷盘请求

public void run() {
    CommitLog.log.info(this.getServiceName() + " service started");

    while (!this.isStopped()) {
        try {
            //等待运行 没有任务就睡眠10毫秒
            this.waitForRunning(10);
            //提交刷盘
            this.doCommit();
        } catch (Exception e) {
            CommitLog.log.warn(this.getServiceName() + " service has exception. ", e);
        }
    }

    // Under normal circumstances shutdown, wait for the arrival of the
    // request, and then flush
    try {
        Thread.sleep(10);
    } catch (InterruptedException e) {
        CommitLog.log.warn("GroupCommitService Exception, ", e);
    }

    synchronized (this) {
        this.swapRequests();
    }

    this.doCommit();

    CommitLog.log.info(this.getServiceName() + " service end");
}
private void doCommit() {
    synchronized (this.requestsRead) {
        if (!this.requestsRead.isEmpty()) {
            //处理刷盘请求
            for (GroupCommitRequest req : this.requestsRead) {
                // There may be a message in the next file, so a maximum of
                // two times the flush
                boolean flushOK = false;
                //刷盘
                for (int i = 0; i < 2 && !flushOK; i++) {
                  	//刷盘指针是否大于写指针
                    flushOK = CommitLog.this.mappedFileQueue.getFlushedWhere() >= req.getNextOffset();
                  	//如果还有数据可以刷就进行刷盘
                    if (!flushOK) {
                        CommitLog.this.mappedFileQueue.flush(0);
                    }
                }
								//唤醒等待刷盘完成的阻塞线程
                req.wakeupCustomer(flushOK);
            }

            long storeTimestamp = CommitLog.this.mappedFileQueue.getStoreTimestamp();
            if (storeTimestamp > 0) {
                CommitLog.this.defaultMessageStore.getStoreCheckpoint().setPhysicMsgTimestamp(storeTimestamp);
            }

            this.requestsRead.clear();
        } else {
            // Because of individual messages is set to not sync flush, it
            // will come to this process
            CommitLog.this.mappedFileQueue.flush(0);
        }
    }
}

这里调用了mappedFileQueue.flush(0)进行刷盘

mappedFileQueue.flush(0)

public boolean flush(final int flushLeastPages) {
    boolean result = true;
    //①根据刷盘指针找到对应的文件
    MappedFile mappedFile = this.findMappedFileByOffset(this.flushedWhere, this.flushedWhere == 0);
    if (mappedFile != null) {
        long tmpTimeStamp = mappedFile.getStoreTimestamp();
        //②核心逻辑调用 mappedFile#flush刷盘
        int offset = mappedFile.flush(flushLeastPages);
        long where = mappedFile.getFileFromOffset() + offset;
        result = where == this.flushedWhere;
        this.flushedWhere = where;
        if (0 == flushLeastPages) {
            this.storeTimestamp = tmpTimeStamp;
        }
    }

    return result;
}

①根据刷盘指针找到对应的文件

②核心逻辑调用 mappedFile#flush刷盘

mappedFile.flush(0)

public int flush(final int flushLeastPages) {
    //①判断是否需要进行刷盘 这里传0的话表示强制刷盘
    if (this.isAbleToFlush(flushLeastPages)) {
        if (this.hold()) {
            //this.writeBuffer == null ? this.wrotePosition.get() : this.committedPosition.get();  writeBuffer存在就用wrotePosition指针,否则用committedPosition指针
            int value = getReadPosition();

            try {
                //We only append data to fileChannel or mappedByteBuffer, never both.
                if (writeBuffer != null || this.fileChannel.position() != 0) {
                    //writeBuffer存在或者fileChannel的position不为0用fileChannel刷盘
                    this.fileChannel.force(false);
                } else {
                    //直接用mappedByteBuffer刷盘
                    this.mappedByteBuffer.force();
                }
            } catch (Throwable e) {
                log.error("Error occurred when force data to disk.", e);
            }
          	//设置刷盘指针
            this.flushedPosition.set(value);
            this.release();
        } else {
            log.warn("in flush, hold failed, flush offset = " + this.flushedPosition.get());
            this.flushedPosition.set(getReadPosition());
        }
    }
    //返回刷盘指针位置
    return this.getFlushedPosition();
}

FlushRealTimeService 异步刷盘

未开启transientStorePoolEnable

public void run() {
    CommitLog.log.info(this.getServiceName() + " service started");

    while (!this.isStopped()) {
        //刷盘线程是否休眠 默认false
        boolean flushCommitLogTimed = CommitLog.this.defaultMessageStore.getMessageStoreConfig().isFlushCommitLogTimed();
        //间隔500毫秒
        int interval = CommitLog.this.defaultMessageStore.getMessageStoreConfig().getFlushIntervalCommitLog();
        //刷盘至少满4页
        int flushPhysicQueueLeastPages = CommitLog.this.defaultMessageStore.getMessageStoreConfig().getFlushCommitLogLeastPages();
        //强制刷盘间隔 10秒 (未满4页也刷盘 防止数据丢失)
        int flushPhysicQueueThoroughInterval =
            CommitLog.this.defaultMessageStore.getMessageStoreConfig().getFlushCommitLogThoroughInterval();

        boolean printFlushProgress = false;

        // Print flush progress
        long currentTimeMillis = System.currentTimeMillis();
        //具体上次强制刷盘时间超过10秒
        if (currentTimeMillis >= (this.lastFlushTimestamp + flushPhysicQueueThoroughInterval)) {
            this.lastFlushTimestamp = currentTimeMillis;
            //设置成0,将触发强制刷盘
            flushPhysicQueueLeastPages = 0;
            printFlushProgress = (printTimes++ % 10) == 0;
        }

        try {
            //刷盘线程是否休眠 默认false
            if (flushCommitLogTimed) {
                Thread.sleep(interval);
            } else {
                //线程阻塞500毫秒 中途可被唤醒
                this.waitForRunning(interval);
            }

            if (printFlushProgress) {
                this.printFlushProgress();
            }

            long begin = System.currentTimeMillis();
            //至少满4页才刷盘 但是每10秒将会强制刷盘一次,flushPhysicQueueLeastPages会被设置为0
            CommitLog.this.mappedFileQueue.flush(flushPhysicQueueLeastPages);
            long storeTimestamp = CommitLog.this.mappedFileQueue.getStoreTimestamp();
            if (storeTimestamp > 0) {
                CommitLog.this.defaultMessageStore.getStoreCheckpoint().setPhysicMsgTimestamp(storeTimestamp);
            }
            long past = System.currentTimeMillis() - begin;
            if (past > 500) {
                log.info("Flush data to disk costs {} ms", past);
            }
        } catch (Throwable e) {
            CommitLog.log.warn(this.getServiceName() + " service has exception. ", e);
            this.printFlushProgress();
        }
    }

CommitRealTimeService

异步将writeBuffer的数据刷到fileChannel

public void run() {
    CommitLog.log.info(this.getServiceName() + " service started");
    while (!this.isStopped()) {
      	//默认200毫秒阻塞等待唤醒
        int interval = CommitLog.this.defaultMessageStore.getMessageStoreConfig().getCommitIntervalCommitLog();
        //至少4页才把数据commit到fileChannel
        int commitDataLeastPages = CommitLog.this.defaultMessageStore.getMessageStoreConfig().getCommitCommitLogLeastPages();
        //强制commit 每隔200毫秒
        int commitDataThoroughInterval =
            CommitLog.this.defaultMessageStore.getMessageStoreConfig().getCommitCommitLogThoroughInterval();

        long begin = System.currentTimeMillis();
        if (begin >= (this.lastCommitTimestamp + commitDataThoroughInterval)) {
            this.lastCommitTimestamp = begin;
            commitDataLeastPages = 0;
        }

        try {
          	//核心逻辑 将数据commit到fileChannel
            boolean result = CommitLog.this.mappedFileQueue.commit(commitDataLeastPages);
            long end = System.currentTimeMillis();
            //result是false 表示有数据commit了
            if (!result) {
                this.lastCommitTimestamp = end; // result = false means some data committed.
                //now wake up flush thread.
                //唤醒刷盘线程
                flushCommitLogService.wakeup();
            }

            if (end - begin > 500) {
                log.info("Commit data to file costs {} ms", end - begin);
            }
            this.waitForRunning(interval);
        } catch (Throwable e) {
            CommitLog.log.error(this.getServiceName() + " service has exception. ", e);
        }
    }

    boolean result = false;
    for (int i = 0; i < RETRY_TIMES_OVER && !result; i++) {
        result = CommitLog.this.mappedFileQueue.commit(0);
        CommitLog.log.info(this.getServiceName() + " service shutdown, retry " + (i + 1) + " times " + (result ? "OK" : "Not OK"));
    }
    CommitLog.log.info(this.getServiceName() + " service end");
}

mappedFileQueue.commit

public boolean commit(final int commitLeastPages) {
    boolean result = true;
    //根据当前已提交偏移量找到对应的文件
    MappedFile mappedFile = this.findMappedFileByOffset(this.committedWhere, this.committedWhere == 0);
    if (mappedFile != null) {
        //委托mappedFile commit数据
        int offset = mappedFile.commit(commitLeastPages);
        long where = mappedFile.getFileFromOffset() + offset;
        result = where == this.committedWhere;
        this.committedWhere = where;
    }

    return result;
}

mappedFile.commit

public int commit(final int commitLeastPages) {
    //writeBuffer是null,这应该是不正常的
    if (writeBuffer == null) {
        //no need to commit data to file channel, so just regard wrotePosition as committedPosition.
        return this.wrotePosition.get();
    }
  	//是否可以进行commit,至少堆积commitLeastPages页数据 为0的话表示强制commit
    if (this.isAbleToCommit(commitLeastPages)) {
        if (this.hold()) {
            //调用commit0
            commit0(commitLeastPages);
            this.release();
        } else {
            log.warn("in commit, hold failed, commit offset = " + this.committedPosition.get());
        }
    }

    // All dirty data has been committed to FileChannel.  文件已经写满且已经全commit,可以把writeBuffer归还给池子里了
    if (writeBuffer != null && this.transientStorePool != null && this.fileSize == this.committedPosition.get()) {
        this.transientStorePool.returnBuffer(writeBuffer);
        this.writeBuffer = null;
    }
  	//返回commit指针
    return this.committedPosition.get();
}
protected void commit0(final int commitLeastPages) {
    int writePos = this.wrotePosition.get();
    int lastCommittedPosition = this.committedPosition.get();
    
    if (writePos - this.committedPosition.get() > 0) {
        try {
            //将lastCommittedPosition和writePos之间的数据刷到fileChannel中
            ByteBuffer byteBuffer = writeBuffer.slice();
            byteBuffer.position(lastCommittedPosition);
            byteBuffer.limit(writePos);
            this.fileChannel.position(lastCommittedPosition);
            this.fileChannel.write(byteBuffer);
            //设置已提交指针为writePos
            this.committedPosition.set(writePos);
        } catch (Throwable e) {
            log.error("Error occurred when commit data to FileChannel.", e);
        }
    }
}
posted @ 2020-07-14 10:02  鹿慕叶  阅读(783)  评论(0编辑  收藏  举报