首頁 > 軟體

使用canal監控mysql資料庫實現elasticsearch索引實時更新問題

2022-03-29 19:02:29

業務場景

  • 使用elasticsearch作為全文搜尋引擎,對標題、內容等,實現智慧搜尋、輸入提示、拼音搜尋等
  • elasticsearch索引與資料庫資料不一致,導致搜尋到不應被搜到的結果,或者搜不到已有資料
  • 索引相關業務,影響其他業務操作,如索引刪除失敗導致資料庫刪除失敗
  • 為了減少對現有業務的侵入,基於資料庫層面,對資訊表進行監控,但需要索引的欄位變動時,更新索引
  • 由於使用的是mysql資料庫,故決定採用alibaba的canal中介軟體
  • 主要是監控資訊基表base,監控這一張表的資料變動,mq訊息消費時,重新從資料庫查詢資料更新或刪除索引(資料無法直接使用,要資料淨化,需要關聯查詢拼接處理等)
  • 大致邏輯

資料庫變動 -> 產生binlog -> canal監控讀取binlog -> 傳送mq -> 索引服務消費mq -> 查詢資料庫 -> 更新索引 -> 訊息ack

安裝

下載安裝

wget 地址解壓即可修改設定即可啟動使用wget 下載太慢了,可以自己下載下來再傳到centos伺服器裡github1.1.5地址:https://github.com/alibaba/canal/releases/tag/canal-1.1.5

資料庫啟用row binlog

  • 修改mysql資料庫 my.cnf
  • 開啟 Binlog 寫入功能,設定 binlog-format 為 ROW 模式
log-bin=mysql-bin # 開啟 binlog
binlog-format=ROW # 選擇 ROW 模式
server_id=1 # 設定 replaction 不要和 canal 的 slaveId 重複

建立canal授權賬號

CREATE USER canal IDENTIFIED BY 'canal';  
GRANT SELECT, REPLICATION SLAVE, REPLICATION CLIENT ON *.* TO 'canal'@'%';
FLUSH PRIVILEGES;

使用

修改組態檔canal.properties

  • 主組態檔canal.properties
  • 設定你的連線canal.destinations = example,預設了個example
  • 啟用rabbitMQ canal.serverMode = rabbitMQ
##################################################
######### 		    RabbitMQ	     #############
# 提前建好 使用者、vhost、exchange
##################################################
rabbitmq.host = 192.168.1.171:5672
rabbitmq.virtual.host = sql
rabbitmq.exchange = sqlBinLogExchange
rabbitmq.username = admin
rabbitmq.password = admin
rabbitmq.deliveryMode = Direct 

設定單個連線

  • canal/conf/
  • 修改instance.properties
  • 需要設定資料庫連線canal.instance.master.address
  • 設定表過濾規則,canal.instance.filter.regex,注意.\
  • 設定路由規則canal.mq.topic

範例如下

#################################################
## mysql serverId , v1.0.26+ will autoGen
# canal.instance.mysql.slaveId=0
# enable gtid use true/false
canal.instance.gtidon=false
# position info 寫連線即可,其他省略,會自動獲取
canal.instance.master.address=192.168.1.175:3306
canal.instance.master.journal.name=
canal.instance.master.position=
canal.instance.master.timestamp=
canal.instance.master.gtid=
# rds oss binlog
canal.instance.rds.accesskey=
canal.instance.rds.secretkey=
canal.instance.rds.instanceId=
# table meta tsdb info 
canal.instance.tsdb.enable=true
#canal.instance.tsdb.url=jdbc:mysql://127.0.0.1:3306/canal_tsdb
#canal.instance.tsdb.dbUsername=canal
#canal.instance.tsdb.dbPassword=canal
#canal.instance.standby.address =
#canal.instance.standby.journal.name =
#canal.instance.standby.position =
#canal.instance.standby.timestamp =
#canal.instance.standby.gtid=
# username/password  先前建好的資料庫使用者名稱密碼
canal.instance.dbUsername=canal
canal.instance.dbPassword=canal
canal.instance.connectionCharset = UTF-8
# enable druid Decrypt database password
canal.instance.enableDruid=false
#canal.instance.pwdPublicKey=MFwwDQYJKoZIhvcNAQEBBQADSwAwSAJBALK4BUxdDltRRE5/zXpVEVPUgunvscYFtEip3pmLlhrWpacX7y7GCMo2/JM6LeHmiiNdH1FWgGCpUfircSwlWKUCAwEAAQ==
# table regex 只監控部分表
canal.instance.filter.regex=.*\.cms_base_content
# table black regex
canal.instance.filter.black.regex=mysql\.slave_.*
# table field filter(format: schema1.tableName1:field1/field2,schema2.tableName2:field1/field2)
#canal.instance.filter.field=test1.t_product:id/subject/keywords,test2.t_company:id/name/contact/ch
# table field black filter(format: schema1.tableName1:field1/field2,schema2.tableName2:field1/field2)
#canal.instance.filter.black.field=test1.t_product:subject/product_image,test2.t_company:id/name/contact/ch
# mq config 這個是routerkey,要設定
canal.mq.topic=anhui_szf
# dynamic topic route by schema or table regex
#canal.mq.dynamicTopic=mytest1.user,mytest2\..*,.*\..*
canal.mq.partition=0
# hash partition config
#canal.mq.partitionsNum=3
#canal.mq.partitionHash=test.table:id^name,.*\..*
#canal.mq.dynamicTopicPartitionNum=test.*:4,mycanal:6

設定多個連線

  • conf下新建資料夾,複製一份instance.properties
  • canal.destinations裡新增上面的資料夾名稱
  • 可以使用不同的canal.mq.topic,路由到不同佇列

設定rabbitMQ

  • 登入你的rabbitMQ管理介面http://192.168.1.***:15672/
  • 確保使用者存在,且有許可權
  • 確保vhost存在,沒使用預設的/,則建立

新建你的exchange

新建你的queue

根據前面設定的topic,作為routerkeyexchangequeue起來

程式改動

canal原始碼

  • 修改CanalRabbitMQProducer.java
  • 實現只監控部分欄位
  • 處理mq訊息體,去除不需要的東西,減少資料傳輸
  • 主要修改了send(MQDestination canalDestination, String topicName, Message messageSub)
package com.alibaba.otter.canal.connector.rabbitmq.producer;
... ... 省略
@SPI("rabbitmq")
public class CanalRabbitMQProducer extends AbstractMQProducer implements CanalMQProducer {
    // 需要監控的操作型別
    private static final String OPERATE_TYPE = "UPDATE,INSERT,DELETE";
    // 更新時,需要觸發傳送mq的欄位
    private static final String[] KEY_FIELDS = new String[]{"COLUMN_ID","TITLE","REDIRECT_LINK","IMAGE_LINK",
            "IS_PUBLISH","PUBLISH_DATE","RECORD_STATUS","IS_TOP","AUTHOR","REMARKS","TO_FILEID","UPDATE_USER_ID"};
    // 資料處理時,需要保留的欄位(需把標題等傳值過去,已刪除資料這些查不到了)
    private static final String[] HOLD_FIELDS = new String[]{"ID", "SITE_ID", "COLUMN_ID", "RECORD_STATUS", "TITLE"};
  ... ... 省略
    private void send(MQDestination canalDestination, String topicName, Message messageSub) {
        if (!mqProperties.isFlatMessage()) {
            byte[] message = CanalMessageSerializerUtil.serializer(messageSub, mqProperties.isFilterTransactionEntry());
            if (logger.isDebugEnabled()) {
                logger.debug("send message:{} to destination:{}", message, canalDestination.getCanalDestination());
            }
            sendMessage(topicName, message);
        } else {
            // 並行構造
            MQMessageUtils.EntryRowData[] datas = MQMessageUtils.buildMessageData(messageSub, buildExecutor);
            // 序列分割區
            List<FlatMessage> flatMessages = MQMessageUtils.messageConverter(datas, messageSub.getId());
            for (FlatMessage flatMessage : flatMessages) {
                if (!OPERATE_TYPE.contains(flatMessage.getType())) {
                    continue;
                }
                // 只有設定的關鍵欄位更新,才會觸發訊息傳送
                if ("UPDATE".equals(flatMessage.getType())) {
                    List<Map<String, String>> olds = flatMessage.getOld();
                    if (olds.size() > 0) {
                        Map<String, String> param = olds.get(0);
                        // 判斷更新欄位是否包含重要欄位,不包含則跳過
                        boolean isSkip = true;
                        for (String keyField : KEY_FIELDS) {
                            if (param.containsKey(keyField) || param.containsKey(keyField.toLowerCase())) {
                                isSkip = false;
                                break;
                            }
                        }
                        if (isSkip) {
                            continue;
                    }
                // 取出data裡面的ID和RECORD_STATUS,只保留這個欄位的值,其餘的捨棄
                if (null != flatMessage.getData()) {
                    List<Map<String, String>> data = flatMessage.getData();
                    if (!data.isEmpty()) {
                        List<Map<String, String>> newData = new ArrayList<>();
                        for(Map<String, String> map : data) {
                            Map<String, String> newMap = new HashMap<>(8);
                            for (String field : HOLD_FIELDS) {
                                if (map.containsKey(field) || map.containsKey(field.toLowerCase())) {
                                    newMap.put(field, map.get(field));
                                }
                            newData.add(newMap);
                        flatMessage.setData(newData);
                // 不需要的欄位註釋掉,較少網路傳輸消耗
                flatMessage.setMysqlType(null);
                flatMessage.setSqlType(null);
                flatMessage.setOld(null);
                flatMessage.setIsDdl(null);
                logger.info("====================================");
                logger.info(JSON.toJSONString(flatMessage));
                byte[] message = JSON.toJSONBytes(flatMessage, SerializerFeature.WriteMapNullValue);
                if (logger.isDebugEnabled()) {
                    logger.debug("send message:{} to destination:{}", message, canalDestination.getCanalDestination());
                sendMessage(topicName, message);
        }
    }
    ... ... 省略
}

微服務消費mq

  • 根據前面的mq設定,建立rabbitMQ連線
  • 根據前面設定好的exchangequeue,消費mq即可
  • 更新或刪除索引
  • ack確認索引更新失敗的,根據情況,nack或者存入失敗表
  • 由於使用的Springboot版本較低,無法使用批次消費介面,只好使用拉模式,主動消費了
  • 部分程式碼
package cn.lonsun.core.middleware.rabbitmq;
import cn.lonsun.core.util.SpringContextHolder;
import cn.lonsun.es.internal.service.IIndexService;
import cn.lonsun.es.internal.service.impl.IndexServiceImpl;
import cn.lonsun.es.vo.MessageVO;
import com.alibaba.fastjson.JSON;
import com.alibaba.fastjson.JSONObject;
import com.rabbitmq.client.Channel;
import com.rabbitmq.client.GetResponse;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import org.springframework.amqp.core.Message;
import org.springframework.amqp.rabbit.core.ChannelAwareMessageListener;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.data.redis.core.RedisTemplate;
import org.springframework.stereotype.Component;
import java.io.IOException;
import java.util.ArrayList;
import java.util.List;
/**
 * @author yanyulin
 * @ClassName: MessageListenerBean
 * @Description: RabbitMQ訊息接收者
 * @date 2022-3-14 15:25
 * @version: 1.0
 */
@Component
public class MessageListenerBean implements ChannelAwareMessageListener {
    private static Logger log = LoggerFactory.getLogger(MessageListenerBean.class);
    @Autowired
    private RedisTemplate redisTemplate;
    // 一次處理多少條訊息,考慮es寫入效能(文字較大時,單個索引可能很大),一次處理200條,模擬剩餘多少條,使用2
    private static final int BATCH_DEAL_COUNT = 2;
    // mq裡待消費執行緒快取KEY
    public static final String WAIT_DEAL = "wait_deal";
    // 集合編碼
    private String code;
    @Override
    public void onMessage(Message message, Channel channel) throws IOException {
        Thread thread=Thread.currentThread();
        long maxDeliveryTag = 0;
        String queuName = message.getMessageProperties().getConsumerQueue();
        // 消費前,更新剩餘待消費訊息數量
        redisTemplate.opsForValue().set(code + "_" + WAIT_DEAL, channel.messageCount(queuName) + 1);
        System.out.println("==============>" + code + "=" + redisTemplate.opsForValue().get(code + "_" + WAIT_DEAL));
        List<MessageVO> messageVOList = new ArrayList<>();
        List<GetResponse> responseList = new ArrayList<>();
        while (responseList.size() < BATCH_DEAL_COUNT) {
            // 需要設定false,手動ack
            GetResponse getResponse = channel.basicGet(queuName, false);
            if (getResponse == null) {
                byte[] body = message.getBody();
                String str = new String(body);
                log.info(code + " deliveryTag:{} message:{}  ThreadId is:{}  ConsumerTag:{}  Queue:{} channel:{}"
                        ,maxDeliveryTag,str,thread.getId(),message.getMessageProperties().getConsumerTag()
                        ,message.getMessageProperties().getConsumerQueue(),channel.getChannelNumber());
                // 開始消費
                MessageVO messageVO = JSONObject.parseObject(str,MessageVO.class);
                log.debug("監聽資料庫cms_base_content表變更記錄訊息,訊息內容: {} ", JSON.toJSONString(messageVO));
                messageVOList.add(messageVO);
                break;
            }
            responseList.add(getResponse);
            maxDeliveryTag = getResponse.getEnvelope().getDeliveryTag();
        }
        try{
            if (!responseList.isEmpty()) {
                for (GetResponse response : responseList) {
                    byte[] body = response.getBody();
                    String str = new String(body);
                    log.info(code + " deliveryTag:{} message:{}  ThreadId is:{}  ConsumerTag:{}  Queue:{} channel:{}"
                            ,maxDeliveryTag,str,thread.getId(),message.getMessageProperties().getConsumerTag()
                            ,message.getMessageProperties().getConsumerQueue(),channel.getChannelNumber());
                    // 開始消費
                    MessageVO messageVO = JSONObject.parseObject(str,MessageVO.class);
                    log.debug("監聽資料庫cms_base_content表變更記錄訊息,訊息內容: {} ", JSON.toJSONString(messageVO));
                    messageVOList.add(messageVO);
                }
            IIndexService indexService = SpringContextHolder.getBean(IndexServiceImpl.class);
            indexService.batchDealIndex(messageVOList, code);
            channel.basicAck(maxDeliveryTag, true);
            // Ack後,更新剩餘待消費訊息數量
            redisTemplate.opsForValue().set(code + "_" + WAIT_DEAL, channel.messageCount(queuName));
            System.out.println("==============>" + code + "=" + redisTemplate.opsForValue().get(code + "_" + WAIT_DEAL));
        }catch(Throwable e){
            log.error("監聽前臺存取記錄訊息,deliveryTag: {} ",maxDeliveryTag,e);
            //成功收到訊息
            try {
                channel.basicNack(maxDeliveryTag,true,true);
            } catch (IOException e1) {
                log.error("ack 異常, 訊息佇列可能出現無法消費情況, 請及時處理",e1);
    }
    public MessageListenerBean() {
    public MessageListenerBean(String code) {
        this.code = code;
}

到此這篇關於使用canal監控mysql資料庫實現elasticsearch索引實時更新的文章就介紹到這了,更多相關canal監控mysql資料庫內容請搜尋it145.com以前的文章或繼續瀏覽下面的相關文章希望大家以後多多支援it145.com!


IT145.com E-mail:sddin#qq.com