消息隊列(七)RocketMQ消息發送

大道至簡,消息隊列能夠簡單歸納爲:「一發一存一收」,在這三個過程當中消息發送最爲簡單,也比較容易入手,適合初中階童鞋做爲MQ研究和學習的切入點。所以,本篇主要從一條消息發送爲切入點,詳細闡述在RocketMQ這款分佈式消息隊列中發送一條普通消息的大體流程和細節。apache

1、RocketMQ網絡架構圖json

RocketMQ分佈式消息隊列的網絡部署架構圖以下圖所示(其中,包含了生產者Producer發送普通消息至集羣的兩條主線)數組

對於上圖中幾個角色的說明:緩存

(1)NameServer:RocketMQ集羣的命名服務器(也能夠說是註冊中心),它自己是無狀態的(實際狀況下可能存在每一個NameServer實例上的數據有短暫的不一致現象,可是經過定時更新,在大部分狀況下都是一致的),用於管理集羣的元數據( 例如,KV配置、Topic、Broker的註冊信息)。bash

(2)Broker(Master):RocketMQ消息代理服務器主節點,起到串聯Producer的消息發送和Consumer的消息消費,和將消息的落盤存儲的做用;服務器

(3)Broker(Slave):RocketMQ消息代理服務器備份節點,主要是經過同步/異步的方式將主節點的消息同步過來進行備份,爲RocketMQ集羣的高可用性提供保障;網絡

(4)Producer(消息生產者):在這裏爲普通消息的生產者,主要基於RocketMQ-Client模塊將消息發送至RocketMQ的主節點。架構

對於上面圖中幾條通訊鏈路的關係:負載均衡

(1)Producer與NamerServer:每個Producer會與NameServer集羣中的一個實例創建TCP鏈接,從這個NameServer實例上拉取Topic路由信息;異步

(2)Producer和Broker:Producer會和它要發送的topic相關聯的Master的Broker代理服務器創建TCP鏈接,用於發送消息以及定時的心跳信息;

(3)Broker和NamerServer:Broker(Master or Slave)均會和每個NameServer實例來創建TCP鏈接。Broker在啓動的時候會註冊本身配置的Topic信息到NameServer集羣的每一臺機器中。即每個NameServer均有該broker的Topic路由配置信息。其中,Master與Master之間無鏈接,Master與Slave之間有鏈接;

2、客戶端發送普通消息的demo方法

在RocketMQ源碼工程的example包下就有最爲簡單的發送普通消息的樣例代碼(ps:對於剛剛接觸RocketMQ的童鞋使用這個包下面的樣例代碼進行系統性的學習和調試)。 咱們能夠直接run下「org.apache.rocketmq.example.simple」包下Producer類的main方法便可完成一次普通消息的發送(主要代碼以下,在這裏需本地將NameServer和Broker實例均部署起來):

//step1.啓動DefaultMQProducer,啓動時的具體流程一下子會詳細說明
        DefaultMQProducer producer = new DefaultMQProducer("ProducerGroupName");
        producer.setNamesrvAddr("127.0.0.1:9876");
        producer.setInstanceName("producer");
        producer.start();

        try {
            {
                //step2.封裝將要發送消息的內容
                Message msg = new Message("TopicTest",
                        "TagA",
                        "OrderID188",
                        "Hello world".getBytes(RemotingHelper.DEFAULT_CHARSET));
                //step3.發送消息流程,具體流程待會兒說
                SendResult sendResult = producer.send(msg);
            }
        } catch (Exception e) {
            //Exception code
        }
        producer.shutdown();
複製代碼

3、RocketMQ發送普通消息的全流程解讀

從上面一節中能夠看出,消息生產者發送消息的demo代碼仍是較爲簡單的,核心就幾行代碼,但在深刻研讀RocketMQ的Client模塊後,發現其發送消息的核心流程仍是有一些複雜的。下面將主要從DefaultMQProducer的啓動流程、send發送方法和Broker代理服務器的消息處理三方面分別進行分析和闡述。

3.1 DefaultMQProducer的啓動流程

在客戶端發送普通消息的demo代碼部分,咱們先是將DefaultMQProducer實例啓動起來,裏面調用了默認生成消息的實現類—DefaultMQProducerImpl的start()方法。

@Override
    public void start() throws MQClientException {
        this.defaultMQProducerImpl.start();
    }
複製代碼

默認生成消息的實現類—DefaultMQProducerImpl的啓動主要流程以下:

(1)初始化獲得MQClientInstance實例對象,並註冊至本地緩存變量—producerTable中;

(2)將默認Topic(「TBW102」)保存至本地緩存變量—topicPublishInfoTable中;

(3)MQClientInstance實例對象調用本身的start()方法,啓動一些客戶端本地的服務線程,如拉取消息服務、客戶端網絡通訊服務、從新負載均衡服務以及其餘若干個定時任務(包括,更新路由/清理下線Broker/發送心跳/持久化consumerOffset/調整線程池),並從新作一次啓動(此次參數爲false);

(4)最後向全部的Broker代理服務器節點發送心跳包;

(1)在一個客戶端中,一個producerGroup只能有一個實例;

(2)根據不一樣的clientId,MQClientManager將給出不一樣的MQClientInstance;

(3)根據不一樣的producerGroup,MQClientInstance將給出不一樣的MQProducer和MQConsumer(保存在本地緩存變量——producerTable和consumerTable中);

3.2 send發送方法的核心流程

經過Rocketmq的用戶端板塊發送消息主要有如下三種方法:

(1)同步方式

(2)異步方式

(3)Oneway方式

其中,用(1)、(2)種方式來發送消息比較常見,具體用哪種方式須要根據業務狀況來判斷。本節內容將結合同步發送方式(同步發送模式下,假若有發送失敗的最多會有3次重試(也能夠自定義),其他模式均1次)進行消息發送核心流程的簡析。用同步方式發送消息核心流程的入口以下:

/**
     * 同步方式發送消息核心流程的入口,默認超時時間爲3s
     *
     * @param msg     發送消息的具體Message內容
     * @param timeout 其中發送消息的超時時間能夠參數設置
     * @return
     * @throws MQClientException
     * @throws RemotingException
     * @throws MQBrokerException
     * @throws InterruptedException
     */
    public SendResult send(Message msg,
        long timeout) throws MQClientException, RemotingException, MQBrokerException, InterruptedException {
        return this.sendDefaultImpl(msg, CommunicationMode.SYNC, null, timeout);
    }
複製代碼

3.2.1 嘗試獲取TopicPublishInfo的路由信息

咱們一步步debug進去後會發如今sendDefaultImpl()方法中先對待發送的消息進行前置的驗證。若是消息的Topic和Body均沒有問題的話,那麼會調用—tryToFindTopicPublishInfo()方法,根據待發送消息的中包含的Topic嘗試從Client端的本地緩存變量—topicPublishInfoTable中查找,若是沒有則會從NameServer上更新Topic的路由信息(其中,調用了MQClientInstance實例的updateTopicRouteInfoFromNameServer方法,最終執行的是MQClientAPIImpl實例的getTopicRouteInfoFromNameServer方法),這裏分別會存在如下兩種場景:

(1)生產者第一次發送消息(此時,Topic在NameServer中並不存在):由於第一次獲取時候並不能從遠端的NameServer上拉取下來並更新本地緩存變量—topicPublishInfoTable成功。所以,第二次須要經過默認Topic—TBW102的TopicRouteData變量來構造TopicPublishInfo對象,並更新DefaultMQProducerImpl實例的本地緩存變量——topicPublishInfoTable。

另外,在該種類型的場景下,當消息發送至Broker代理服務器時,在SendMessageProcessor業務處理器的sendBatchMessage/sendMessage方法裏面的super.msgCheck(ctx, requestHeader, response)消息前置校驗中,會調用TopicConfigManager的createTopicInSendMessageMethod方法,在Broker端完成新Topic的建立並持久化至配置文件中(配置文件路徑:{rocketmq.home.dir}/store/config/topics.json)。(ps:該部份內容其實屬於Broker有點超本篇的範圍,不過因爲涉及新Topic的建立所以在略微提了下)

(2)生產者發送Topic已存在的消息:因爲在NameServer中已經存在了該Topic,所以在第一次獲取時候就可以取到而且更新至本地緩存變量中topicPublishInfoTable,隨後tryToFindTopicPublishInfo方法直接能夠return。 在RocketMQ中該部分的核心方法源碼以下(已經加了註釋):

/**
     * 根據msg的topic從topicPublishInfoTable獲取對應的topicPublishInfo
     * 若是沒有則更新路由信息,從nameserver端拉取最新路由信息
     *
     * topicPublishInfo
     * 
     * @param topic
     * @return
     */
    private TopicPublishInfo tryToFindTopicPublishInfo(final String topic) {
        //step1.先從本地緩存變量topicPublishInfoTable中先get一次
        TopicPublishInfo topicPublishInfo = this.topicPublishInfoTable.get(topic);
        if (null == topicPublishInfo || !topicPublishInfo.ok()) {
            this.topicPublishInfoTable.putIfAbsent(topic, new TopicPublishInfo());
            //step1.2 而後從nameServer上更新topic路由信息
            this.mQClientFactory.updateTopicRouteInfoFromNameServer(topic);
            //step2 而後再從本地緩存變量topicPublishInfoTable中再get一次
            topicPublishInfo = this.topicPublishInfoTable.get(topic);
        }

        if (topicPublishInfo.isHaveTopicRouterInfo() || topicPublishInfo.ok()) {
            return topicPublishInfo;
        } else {
            /**
             *  第一次的時候isDefault爲false,第二次的時候default爲true,即爲用默認的topic的參數進行更新
             */
            this.mQClientFactory.updateTopicRouteInfoFromNameServer(topic, true, this.defaultMQProducer);
            topicPublishInfo = this.topicPublishInfoTable.get(topic);
            return topicPublishInfo;
        }
    }
複製代碼
/**
     * 本地緩存中不存在時從遠端的NameServer註冊中心中拉取Topic路由信息
     *
     * @param topic
     * @param timeoutMillis
     * @param allowTopicNotExist
     * @return
     * @throws MQClientException
     * @throws InterruptedException
     * @throws RemotingTimeoutException
     * @throws RemotingSendRequestException
     * @throws RemotingConnectException
     */
    public TopicRouteData getTopicRouteInfoFromNameServer(final String topic, final long timeoutMillis,
        boolean allowTopicNotExist) throws MQClientException, InterruptedException, RemotingTimeoutException, RemotingSendRequestException, RemotingConnectException {
        GetRouteInfoRequestHeader requestHeader = new GetRouteInfoRequestHeader();
        requestHeader.setTopic(topic);
        //設置請求頭中的Topic參數後,發送獲取Topic路由信息的request請求給NameServer
        RemotingCommand request = RemotingCommand.createRequestCommand(RequestCode.GET_ROUTEINTO_BY_TOPIC, requestHeader);
       //這裏因爲是同步方式發送,因此直接return response的響應
        RemotingCommand response = this.remotingClient.invokeSync(null, request, timeoutMillis);
        assert response != null;
        switch (response.getCode()) {
            //若是NameServer中不存在待發送消息的Topic
            case ResponseCode.TOPIC_NOT_EXIST: {
                if (allowTopicNotExist && !topic.equals(MixAll.DEFAULT_TOPIC)) {
                    log.warn("get Topic [{}] RouteInfoFromNameServer is not exist value", topic);
                }

                break;
            }
            //若是獲取Topic存在,則成功返回,利用TopicRouteData進行解碼,且直接返回TopicRouteData
            case ResponseCode.SUCCESS: {
                byte[] body = response.getBody();
                if (body != null) {
                    return TopicRouteData.decode(body, TopicRouteData.class);
                }
            }
            default:
                break;
        }

        throw new MQClientException(response.getCode(), response.getRemark());
    }
複製代碼

將TopicRouteData轉換至TopicPublishInfo路由信息的映射圖以下:

TopicRouteData變量內容.jpg
TopicPublishInfo變量內容.jpg

3.2.2 選擇消息發送的隊列

在獲取了TopicPublishInfo路由信息後,RocketMQ的客戶端在默認方式下,selectOneMessageQueuef()方法會從TopicPublishInfo中的messageQueueList中選擇一個隊列(MessageQueue)進行發送消息。具體的容錯策略均在MQFaultStrategy這個類中定義:

public class MQFaultStrategy {
    //維護每一個Broker發送消息的延遲
    private final LatencyFaultTolerance<String> latencyFaultTolerance = new LatencyFaultToleranceImpl();
    //發送消息延遲容錯開關
    private boolean sendLatencyFaultEnable = false;
    //延遲級別數組
    private long[] latencyMax = {50L, 100L, 550L, 1000L, 2000L, 3000L, 15000L};
    //不可用時長數組
    private long[] notAvailableDuration = {0L, 0L, 30000L, 60000L, 120000L, 180000L, 600000L};
  ......
}
複製代碼

這裏經過一個sendLatencyFaultEnable開關來進行選擇採用下面哪一種方式:

(1)sendLatencyFaultEnable開關打開:在隨機遞增取模的基礎上,再過濾掉not available的Broker代理。所謂的"latencyFaultTolerance",是指對以前失敗的,按必定的時間作退避。例如,若是上次請求的latency超過550Lms,就退避3000Lms;超過1000L,就退避60000L。

(2)sendLatencyFaultEnable開關關閉(默認關閉):採用隨機遞增取模的方式選擇一個隊列(MessageQueue)來發送消息。

/**
     * 根據sendLatencyFaultEnable開關是否打開來分兩種狀況選擇隊列發送消息
     * @param tpInfo
     * @param lastBrokerName
     * @return
     */
    public MessageQueue selectOneMessageQueue(final TopicPublishInfo tpInfo, final String lastBrokerName) {
        if (this.sendLatencyFaultEnable) {
            try {

                //1.在隨機遞增取模的基礎上,再過濾掉not available的Broker代理;對以前失敗的,按必定的時間作退避
                int index = tpInfo.getSendWhichQueue().getAndIncrement();
                for (int i = 0; i < tpInfo.getMessageQueueList().size(); i++) {
                    int pos = Math.abs(index++) % tpInfo.getMessageQueueList().size();
                    if (pos < 0)
                        pos = 0;
                    MessageQueue mq = tpInfo.getMessageQueueList().get(pos);
                    if (latencyFaultTolerance.isAvailable(mq.getBrokerName())) {
                        if (null == lastBrokerName || mq.getBrokerName().equals(lastBrokerName))
                            return mq;
                    }
                }

                final String notBestBroker = latencyFaultTolerance.pickOneAtLeast();
                int writeQueueNums = tpInfo.getQueueIdByBroker(notBestBroker);
                if (writeQueueNums > 0) {
                    final MessageQueue mq = tpInfo.selectOneMessageQueue();
                    if (notBestBroker != null) {
                        mq.setBrokerName(notBestBroker);
                        mq.setQueueId(tpInfo.getSendWhichQueue().getAndIncrement() % writeQueueNums);
                    }
                    return mq;
                } else {
                    latencyFaultTolerance.remove(notBestBroker);
                }
            } catch (Exception e) {
                log.error("Error occurred when selecting message queue", e);
            }

            return tpInfo.selectOneMessageQueue();
        }

        //2.採用隨機遞增取模的方式選擇一個隊列(MessageQueue)來發送消息
        return tpInfo.selectOneMessageQueue(lastBrokerName);
    }
複製代碼

3.2.3 發送封裝後的RemotingCommand數據包

在選擇完發送消息的隊列後,RocketMQ就會調用sendKernelImpl()方法發送消息(該方法爲,經過RocketMQ的Remoting通訊模塊真正發送消息的核心)。在該方法內總共完成如下幾個步流程:

(1)根據前面獲取到的MessageQueue中的brokerName,調用MQClientInstance實例的findBrokerAddressInPublish()方法,獲得待發送消息中存放的Broker代理服務器地址,若是沒有找到則跟新路由信息;

(2)若是沒有禁用,則發送消息先後會有鉤子函數的執行(executeSendMessageHookBefore()/executeSendMessageHookAfter()方法);

(3)將與該消息相關信息封裝成RemotingCommand數據包,其中請求碼RequestCode爲如下幾種之一:

a.SEND_MESSAGE(普通發送消息)

b.SEND_MESSAGE_V2(優化網絡數據包發送)c.SEND_BATCH_MESSAGE(消息批量發送)

(4)根據獲取到的Broke代理服務器地址,將封裝好的RemotingCommand數據包發送對應的Broker上,默認發送超時間爲3s

(5)這裏,真正調用RocketMQ的Remoting通訊模塊完成消息發送是在MQClientAPIImpl實例sendMessageSync()方法中,代碼具體以下:

private SendResult sendMessageSync(
        final String addr,
        final String brokerName,
        final Message msg,
        final long timeoutMillis,
        final RemotingCommand request
    ) throws RemotingException, MQBrokerException, InterruptedException {
        RemotingCommand response = this.remotingClient.invokeSync(addr, request, timeoutMillis);
        assert response != null;
        return this.processSendResponse(brokerName, msg, response);
    }
複製代碼

(6)processSendResponse方法對發送正常和異常狀況分別進行不一樣的處理並返回sendResult對象;

(7)發送返回後,調用updateFaultItem更新Broker代理服務器的可用時間;

(8)對於異常狀況,且標誌位—retryAnotherBrokerWhenNotStoreOK,設置爲true時,在發送失敗的時候,會選擇換一個Broker;

在生產者發送完成消息後,客戶端日誌打印以下:

SendResult [sendStatus=SEND_OK, msgId=020003670EC418B4AAC208AD46930000, offsetMsgId=AC1415A200002A9F000000000000017A, messageQueue=MessageQueue [topic=TopicTest, brokerName=HQSKCJJIDRRD6KC, queueId=2], queueOffset=1]


複製代碼

3.3 Broker代理服務器的消息處理簡析

Broker代理服務器中存在不少Processor業務處理器,用於處理不一樣類型的請求,其中一個或者多個Processor會共用一個業務處理器線程池。對於接收到消息,Broker會使用SendMessageProcessor這個業務處理器來處理。SendMessageProcessor會依次作如下處理:

(1)消息前置校驗,包括broker是否可寫、校驗queueId是否超過指定大小、消息中的Topic路由信息是否存在,若是不存在就新建一個。這裏與上文中「嘗試獲取TopicPublishInfo的路由信息」一節中介紹的內容對應。若是Topic路由信息不存在,則Broker端日誌輸出以下:

2018-06-14 17:17:24 INFO SendMessageThread_1 - receive SendMessage request command, RemotingCommand [code=310, language=JAVA, version=252, opaque=6, flag(B)=0, remark=null, extFields={a=ProducerGroupName, b=TopicTest, c=TBW102, d=4, e=2, f=0, g=1528967815569, h=0, i=KEYSOrderID188UNIQ_KEY020003670EC418B4AAC208AD46930000WAITtrueTAGSTagA, j=0, k=false, m=false}, serializeTypeCurrentRPC=JSON]
2018-06-14 17:17:24 WARN SendMessageThread_1 - the topic TopicTest not exist, producer: /172.20.21.162:62661
2018-06-14 17:17:24 INFO SendMessageThread_1 - Create new topic by default topic:[TBW102] config:[TopicConfig [topicName=TopicTest, readQueueNums=4, writeQueueNums=4, perm=RW-, topicFilterType=SINGLE_TAG, topicSysFlag=0, order=false]] producer:[172.20.21.162:62661]
複製代碼

Topic路由信息新建後,第二次消息發送後,Broker端日誌輸出以下:

2018-08-02 16:26:13 INFO SendMessageThread_1 - receive SendMessage request command, RemotingCommand [code=310, language=JAVA, version=253, opaque=6, flag(B)=0, remark=null, extFields={a=ProducerGroupName, b=TopicTest, c=TBW102, d=4, e=2, f=0, g=1533198373524, h=0, i=KEYSOrderID188UNIQ_KEY020003670EC418B4AAC208AD46930000WAITtrueTAGSTagA, j=0, k=false, m=false}, serializeTypeCurrentRPC=JSON]
2018-08-02 16:26:13 INFO SendMessageThread_1 - the msgInner's content is:MessageExt [queueId=2, storeSize=0, queueOffset=0, sysFlag=0, bornTimestamp=1533198373524, bornHost=/172.20.21.162:53914, storeTimestamp=0, storeHost=/172.20.21.162:10911, msgId=null, commitLogOffset=0, bodyCRC=0, reconsumeTimes=0, preparedTransactionOffset=0, toString()=Message [topic=TopicTest, flag=0, properties={KEYS=OrderID188, UNIQ_KEY=020003670EC418B4AAC208AD46930000, WAIT=true, TAGS=TagA}, body=11body's content is:Hello world]]

複製代碼

(2)構建MessageExtBrokerInner;

(3)調用「brokerController.getMessageStore().putMessage」將MessageExtBrokerInner作落盤持久化處理;

(4)根據消息落盤結果(正常/異常狀況),BrokerStatsManager作一些統計數據的更新,最後設置Response並返回;

note:我走得很慢,可是我從不後悔。

相關文章
相關標籤/搜索