在RocketMQ中,Broker通过SendMessageProcessor来
接收和处理producer发送过来的消息。
- private RemotingCommand sendMessage(final ChannelHandlerContext ctx,
- final RemotingCommand request,
- final SendMessageContext sendMessageContext,
- final SendMessageRequestHeader requestHeader) throws RemotingCommandException {
-
- //1、构建Response的Header
- final RemotingCommand response = RemotingCommand.createResponseCommand(SendMessageResponseHeader.class);
- final SendMessageResponseHeader responseHeader = (SendMessageResponseHeader)response.readCustomHeader();
-
- response.setOpaque(request.getOpaque());
-
- response.addExtField(MessageConst.PROPERTY_MSG_REGION, this.brokerController.getBrokerConfig().getRegionId());
- response.addExtField(MessageConst.PROPERTY_TRACE_SWITCH, String.valueOf(this.brokerController.getBrokerConfig().isTraceOn()));
-
- log.debug("receive SendMessage request command, {}", request);
- //2、判断当前时间broker是否提供服务,不提供则返回code为SYSTEM_ERROR的response
- final long startTimstamp = this.brokerController.getBrokerConfig().getStartAcceptSendRequestTimeStamp();
- if (this.brokerController.getMessageStore().now() < startTimstamp) {//broker还没开始提供接收消息服务
- response.setCode(ResponseCode.SYSTEM_ERROR);
- response.setRemark(String.format("broker unable to service, until %s", UtilAll.timeMillisToHumanString2(startTimstamp)));
- return response;
- }
-
- response.setCode(-1);
- //3、检查topic和queue,如果不存在且broker设置中允许自动创建,则自动创建
- super.msgCheck(ctx, requestHeader, response);
- if (response.getCode() != -1) {
- return response;
- }
-
- final byte[] body = request.getBody();
-
- int queueIdInt = requestHeader.getQueueId();
- //4、获取topic的配置
- TopicConfig topicConfig = this.brokerController.getTopicConfigManager().selectTopicConfig(requestHeader.getTopic());
- //5、如果消息中的queueId小于0,则随机选取一个queue
- if (queueIdInt < 0) {
- queueIdInt = Math.abs(this.random.nextInt() % 99999999) % topicConfig.getWriteQueueNums();
- }
- //6、重新封装request中的message成MessageExtBrokerInner
- MessageExtBrokerInner msgInner = new MessageExtBrokerInner();
- msgInner.setTopic(requestHeader.getTopic());
- msgInner.setQueueId(queueIdInt);
- //7、对于RETRY消息,1)判断是否consumer还存在
- // 2)如果超过最大重发次数,尝试创建DLQ,并将topic设置成DeadQueue,消息将被存入死信队列
- if (!handleRetryAndDLQ(requestHeader, response, request, msgInner, topicConfig)) {
- return response;
- }
-
- msgInner.setBody(body);
- msgInner.setFlag(requestHeader.getFlag());
- MessageAccessor.setProperties(msgInner, MessageDecoder.string2messageProperties(requestHeader.getProperties()));
- msgInner.setPropertiesString(requestHeader.getProperties());
- msgInner.setBornTimestamp(requestHeader.getBornTimestamp());
- msgInner.setBornHost(ctx.channel().remoteAddress());
- msgInner.setStoreHost(this.getStoreHost());
- msgInner.setReconsumeTimes(requestHeader.getReconsumeTimes() == null ? 0 : requestHeader.getReconsumeTimes());
- PutMessageResult putMessageResult = null;
- Map
oriProps = MessageDecoder.string2messageProperties(requestHeader.getProperties()); - String traFlag = oriProps.get(MessageConst.PROPERTY_TRANSACTION_PREPARED);
- if (traFlag != null && Boolean.parseBoolean(traFlag)) {
- //如果是事务消息
- if (this.brokerController.getBrokerConfig().isRejectTransactionMessage()) {
- response.setCode(ResponseCode.NO_PERMISSION);
- response.setRemark(
- "the broker[" + this.brokerController.getBrokerConfig().getBrokerIP1()
- + "] sending transaction message is forbidden");
- return response;
- }
- putMessageResult = this.brokerController.getTransactionalMessageService().prepareMessage(msgInner);
- } else {
- //8、调用MessageStore接口存储消息
- putMessageResult = this.brokerController.getMessageStore().putMessage(msgInner);
- }
- //9、根据putResult设置repsonse状态,更新broker统计信息,成功则回复producer,更新context上下文
- return handlePutMessageResult(putMessageResult, response, request, msgInner, responseHeader, sendMessageContext, ctx, queueIdInt);
- }
在步骤3中,会对topic进行检查,如果topic不存在,且设置成自动创建topic,就会在Broker上自动创建topic。
Broker最后调用MessageStore来存储数据。
MessageStore保存消息
DefaultMessageStore#putMessage
- public PutMessageResult putMessage(MessageExtBrokerInner msg) {
- if (this.shutdown) {
- log.warn("message store has shutdown, so putMessage is forbidden");
- return new PutMessageResult(PutMessageStatus.SERVICE_NOT_AVAILABLE, null);
- }
-
- // 从节点不允许写入
- if (BrokerRole.SLAVE == this.messageStoreConfig.getBrokerRole()) {
- long value = this.printTimes.getAndIncrement();
- if ((value % 50000) == 0) {
- log.warn("message store is slave mode, so putMessage is forbidden ");
- }
-
- return new PutMessageResult(PutMessageStatus.SERVICE_NOT_AVAILABLE, null);
- }
-
- // store是否允许写入
- if (!this.runningFlags.isWriteable()) {
- long value = this.printTimes.getAndIncrement();
- if ((value % 50000) == 0) {
- log.warn("message store is not writeable, so putMessage is forbidden " + this.runningFlags.getFlagBits());
- }
-
- return new PutMessageResult(PutMessageStatus.SERVICE_NOT_AVAILABLE, null);
- } else {
- this.printTimes.set(0);
- }
-
- // topic过长
- if (msg.getTopic().length() > Byte.MAX_VALUE) {
- log.warn("putMessage message topic length too long " + msg.getTopic().length());
- return new PutMessageResult(PutMessageStatus.MESSAGE_ILLEGAL, null);
- }
-
- // 消息附加属性过长
- if (msg.getPropertiesString() != null && msg.getPropertiesString().length() > Short.MAX_VALUE) {
- log.warn("putMessage message properties length too long " + msg.getPropertiesString().length());
- return new PutMessageResult(PutMessageStatus.PROPERTIES_SIZE_EXCEEDED, null);
- }
-
- if (this.isOSPageCacheBusy()) {
- return new PutMessageResult(PutMessageStatus.OS_PAGECACHE_BUSY, null);
- }
-
- long beginTime = this.getSystemClock().now();
- // 添加消息到commitLog
- PutMessageResult result = this.commitLog.putMessage(msg);
-
- long eclipseTime = this.getSystemClock().now() - beginTime;
- if (eclipseTime > 500) {
- log.warn("putMessage not in lock eclipse time(ms)={}, bodyLength={}", eclipseTime, msg.getBody().length);
- }
- this.storeStatsService.setPutMessageEntireTimeMax(eclipseTime);
-
- if (null == result || !result.isOk()) {
- this.storeStatsService.getPutMessageFailedTimes().incrementAndGet();
- }
-
- return result;
- }
putMessage会做一下检查,然后调用CommitLog的putMessage方法来写入消息。
CommitLog保存消息
- public PutMessageResult putMessage(final MessageExtBrokerInner msg) {
- // 1、Set the storage time
- msg.setStoreTimestamp(System.currentTimeMillis());
- // 2、Set the message body BODY CRC (consider the most appropriate setting
- // on the client)
- msg.setBodyCRC(UtilAll.crc32(msg.getBody()));
- // Back to Results
- AppendMessageResult result = null;
-
- StoreStatsService storeStatsService = this.defaultMessageStore.getStoreStatsService();
-
- String topic = msg.getTopic();
- int queueId = msg.getQueueId();
-
- final int tranType = MessageSysFlag.getTransactionValue(msg.getSysFlag());
- if (tranType == MessageSysFlag.TRANSACTION_NOT_TYPE
- || tranType == MessageSysFlag.TRANSACTION_COMMIT_TYPE) {
- //非事务消息
- // Delay Delivery
- if (msg.getDelayTimeLevel() > 0) {
- //3、延时投放消息,变更topic
- if (msg.getDelayTimeLevel() > this.defaultMessageStore.getScheduleMessageService().getMaxDelayLevel()) {
- msg.setDelayTimeLevel(this.defaultMessageStore.getScheduleMessageService().getMaxDelayLevel());
- }
-
- topic = ScheduleMessageService.SCHEDULE_TOPIC;
- queueId = ScheduleMessageService.delayLevel2QueueId(msg.getDelayTimeLevel());
-
- // Backup real topic, queueId
- MessageAccessor.putProperty(msg, MessageConst.PROPERTY_REAL_TOPIC, msg.getTopic());
- MessageAccessor.putProperty(msg, MessageConst.PROPERTY_REAL_QUEUE_ID, String.valueOf(msg.getQueueId()));
- msg.setPropertiesString(MessageDecoder.messageProperties2String(msg.getProperties()));
-
- msg.setTopic(topic);
- msg.setQueueId(queueId);
- }
- }
-
- long eclipseTimeInLock = 0;
- MappedFile unlockMappedFile = null;
- //4、获取当前正在写入文件
- MappedFile mappedFile = this.mappedFileQueue.getLastMappedFile();
- //5、获取写message的锁
- putMessageLock.lock(); //spin or ReentrantLock ,depending on store config
- try {
- long beginLockTimestamp = this.defaultMessageStore.getSystemClock().now();
- this.beginTimeInLock = beginLockTimestamp;//记录lock time
-
- // Here settings are stored timestamp, in order to ensure an orderly
- // global
- msg.setStoreTimestamp(beginLockTimestamp);
- //6、新建一个mapp file如果文件不存在或者文件已经写满
- if (null == mappedFile || mappedFile.isFull()) {
- mappedFile = this.mappedFileQueue.getLastMappedFile(0); // Mark: NewFile may be cause noise
- }
- if (null == mappedFile) {
- //文件创建失败,则返回错误
- log.error("create mapped file1 error, topic: " + msg.getTopic() + " clientAddr: " + msg.getBornHostString());
- beginTimeInLock = 0;
- return new PutMessageResult(PutMessageStatus.CREATE_MAPEDFILE_FAILED, null);
- }
- //7、消息写文件
- result = mappedFile.appendMessage(msg, this.appendMessageCallback);
- switch (result.getStatus()) {
- case PUT_OK:
- break;
- case END_OF_FILE:
- //8、如果文件已满,则新建一个文件继续
- unlockMappedFile = mappedFile;
- // Create a new file, re-write the message
- mappedFile = this.mappedFileQueue.getLastMappedFile(0);
- if (null == mappedFile) {
- log.error("create mapped file2 error, topic: " + msg.getTopic() + " clientAddr: " + msg.getBornHostString());
- beginTimeInLock = 0;
- return new PutMessageResult(PutMessageStatus.CREATE_MAPEDFILE_FAILED, result);
- }
- result = mappedFile.appendMessage(msg, this.appendMessageCallback);
- break;
- case MESSAGE_SIZE_EXCEEDED:
- case PROPERTIES_SIZE_EXCEEDED:
- beginTimeInLock = 0;
- return new PutMessageResult(PutMessageStatus.MESSAGE_ILLEGAL, result);
- case UNKNOWN_ERROR:
- beginTimeInLock = 0;
- return new PutMessageResult(PutMessageStatus.UNKNOWN_ERROR, result);
- default:
- beginTimeInLock = 0;
- return new PutMessageResult(PutMessageStatus.UNKNOWN_ERROR, result);
- }
-
- eclipseTimeInLock = this.defaultMessageStore.getSystemClock().now() - beginLockTimestamp;
- beginTimeInLock = 0;
- } finally {
- //9、释放第5)步中获取到的锁
- putMessageLock.unlock();
- }
-
- if (eclipseTimeInLock > 500) {//写消息时间过长
- log.warn("[NOTIFYME]putMessage in lock cost time(ms)={}, bodyLength={} AppendMessageResult={}", eclipseTimeInLock, msg.getBody().length, result);
- }
- //unlock已经写满的文件,释放内存锁
- if (null != unlockMappedFile && this.defaultMessageStore.getMessageStoreConfig().isWarmMapedFileEnable()) {
- this.defaultMessageStore.unlockMappedFile(unlockMappedFile);
- }
-
- PutMessageResult putMessageResult = new PutMessageResult(PutMessageStatus.PUT_OK, result);
-
- // Statistics
- storeStatsService.getSinglePutMessageTopicTimesTotal(msg.getTopic()).incrementAndGet();
- storeStatsService.getSinglePutMessageTopicSizeTotal(topic).addAndGet(result.getWroteBytes());
- //10、flush数据到磁盘,分同步和异步
- handleDiskFlush(result, putMessageResult, msg);
- //11、如果broker设置成SYNC_MASTER,则等SLAVE接收到数据后才返回(接收到数据是指offset延后没有超过制定的字节数)
- handleHA(result, putMessageResult, msg);
-
- return putMessageResult;
- }
SCHEDULE_TOPIC_XXXX
,根据延时时长计算queueId。将原始的topic和queueId放到消息的properties字段中。这样这个消息只会被重发的Schedule任务读到。MessageStore
的时候讲过,CommitLog
是由连续的MappedFile的列表组成的。在同一时间,只有最后一个MappedFile有写入,因为之前的文件都已经写满了,所以这里是取最后一个。appendMessage()
接口中,如果文件剩余的空间已经不足以写下这条消息,则会用一个EOF消息补齐文件,然后返回一个EOF错误。在收到这个错误时,会新建一个文件,然后重写一次。MessageStore
的FlushDiskType
参数来控制数据flush到磁盘的方式,如果参数值SYNC_FLUSH
,则每次写完消息都会做一次flush,完成才会返回结果。如果是ASYNC_FLUSH
,只会唤醒flushCommitLogService
,由它异步的去检查是否要做flush。SYNC_MASTER
,则Master保存消息后,需要将消息同步给slave后才会返回结果。如果ASYNC_MASTER
,这里不会做任何操作,由HAService的后台线程做数据同步。MappedFile消息写入
- public AppendMessageResult appendMessagesInner(final MessageExt messageExt, final AppendMessageCallback cb) {
- assert messageExt != null;
- assert cb != null;
- //1、获取当前的write position
- int currentPos = this.wrotePosition.get();
-
- if (currentPos < this.fileSize) {
- //2、生成buffer切片
- ByteBuffer byteBuffer = writeBuffer != null ? writeBuffer.slice() : this.mappedByteBuffer.slice();
- byteBuffer.position(currentPos);
- AppendMessageResult result = null;
- if (messageExt instanceof MessageExtBrokerInner) {
- //3、写单条消息到byteBuffer
- result = cb.doAppend(this.getFileFromOffset(), byteBuffer, this.fileSize - currentPos, (MessageExtBrokerInner) messageExt);
- } else if (messageExt instanceof MessageExtBatch) {
- //3、批量消息到byteBuffer
- result = cb.doAppend(this.getFileFromOffset(), byteBuffer, this.fileSize - currentPos, (MessageExtBatch) messageExt);
- } else {
- return new AppendMessageResult(AppendMessageStatus.UNKNOWN_ERROR);
- }
- //4、更新write position,到最新值
- this.wrotePosition.addAndGet(result.getWroteBytes());
- this.storeTimestamp = result.getStoreTimestamp();
- return result;
- }
- log.error("MappedFile.appendMessage return null, wrotePosition: {} fileSize: {}", currentPos, this.fileSize);
- return new AppendMessageResult(AppendMessageStatus.UNKNOWN_ERROR);
- }
消息写入首先是获取ByteBuffer,从第2步中可以发现有个判断,这里是因为MappedFile写数据到文件有两种实现方式:
FileChannel
获取直接内存映射,收到消息后,将数据写入到这块内存中,内存和物理文件的数据交互由操作系统负责ByteBuffer
申请的堆外内存),消息数据首先写入内存池中,然后后台有个线程定时将内存池中的数据commit到FileChannel
中。这种方式只有MessageStore
是ASYNC模式时才能开启。代码中if判断writeBuffer不为空的情况就是使用的这种写入方式。第3步,最终回调的Callback类将数据写入buffer中,消息的序列化也是在callback里面完成的。