溫馨提示×

溫馨提示×

您好,登錄后才能下訂單哦!

密碼登錄×
登錄注冊×
其他方式登錄
點擊 登錄注冊 即表示同意《億速云用戶服務(wù)條款》

spring?kafka框架中@KafkaListener注解怎么使用

發(fā)布時間:2023-02-25 11:42:55 來源:億速云 閱讀:149 作者:iii 欄目:開發(fā)技術(shù)

這篇文章主要介紹“spring kafka框架中@KafkaListener注解怎么使用”,在日常操作中,相信很多人在spring kafka框架中@KafkaListener注解怎么使用問題上存在疑惑,小編查閱了各式資料,整理出簡單好用的操作方法,希望對大家解答”spring kafka框架中@KafkaListener注解怎么使用”的疑惑有所幫助!接下來,請跟著小編一起來學(xué)習吧!

    簡介

    Kafka 目前主要作為一個分布式的發(fā)布訂閱式的消息系統(tǒng)使用,也是目前最流行的消息隊列系統(tǒng)之一。因此,也越來越多的框架對 kafka 做了集成,比如本文將要說到的 spring-kafka。

    Kafka 既然作為一個消息發(fā)布訂閱系統(tǒng),就包括消息生成者和消息消費者。本文主要講述的 spring-kafka 框架的 kafkaListener 注解的深入解讀和使用案例。

    解讀

    源碼解讀

    @Target({ ElementType.TYPE, ElementType.METHOD, ElementType.ANNOTATION_TYPE })
    
    @Retention(RetentionPolicy.RUNTIME)
    
    @MessageMapping
    
    @Documented
    
    @Repeatable(KafkaListeners.class)
    
    public @interface KafkaListener {
       /**
    
        * 消費者的id,當GroupId沒有被配置的時候,默認id為GroupId
    
        */
    
       String id() default "";
       /**
    
        * 監(jiān)聽容器工廠,當監(jiān)聽時需要區(qū)分單數(shù)據(jù)還是多數(shù)據(jù)消費需要配置containerFactory      屬性
    
        */
    
       String containerFactory() default "";
       /**
    
        * 需要監(jiān)聽的Topic,可監(jiān)聽多個,和 topicPattern 屬性互斥
    */
    
       String[] topics() default {};
       /**
    
        * 需要監(jiān)聽的Topic的正則表達。和 topics,topicPartitions屬性互斥
        */
    
       String topicPattern() default "";
       /**
    
        * 可配置更加詳細的監(jiān)聽信息,必須監(jiān)聽某個Topic中的指定分區(qū),或者從offset為200的偏移量開始監(jiān)聽,可配置該參數(shù), 和 topicPattern 屬性互斥
        */
    
       TopicPartition[] topicPartitions() default {};
       /**
    
        *偵聽器容器組 
    
        */
    
       String containerGroup() default "";
       /**
    
        * 監(jiān)聽異常處理器,配置BeanName
    
        */
    
       String errorHandler() default "";
       /**
    
        * 消費組ID 
    
        */
    
       String groupId() default "";
       /**
    
        * id是否為GroupId
    
        */
    
       boolean idIsGroup() default true;
       /**
    
        * 消費者Id前綴
    
        */
    
       String clientIdPrefix() default "";
       /**
    
        * 真實監(jiān)聽容器的BeanName,需要在 BeanName前加 "__"
    
        */
    
       String beanRef() default "__listener";
    }

    使用案例

    ConsumerRecord 類消費

    使用 ConsumerRecord 類接收有一定的好處,ConsumerRecord 類里面包含分區(qū)信息、消息頭、消息體等內(nèi)容,如果業(yè)務(wù)需要獲取這些參數(shù)時,使用 ConsumerRecord 會是個不錯的選擇。如果使用具體的類型接收消息體則更加方便,比如說用 String 類型去接收消息體。

    這里我們編寫一個 Listener 方法,監(jiān)聽 "topic1"Topic,并把 ConsumerRecord 里面所包含的內(nèi)容打印到控制臺中:

    @Component
    
    public class Listener {
        private static final Logger log = LoggerFactory.getLogger(Listener.class);
        @KafkaListener(id = "consumer", topics = "topic1")
    
        public void consumerListener(ConsumerRecord record) {
    
            log.info("topic.quick.consumer receive : " + record.toString());
    
        }
    }

    批量消費

    批量消費在現(xiàn)實業(yè)務(wù)場景中是很有實用性的。因為批量消費可以增大 kafka 消費吞吐量, 提高性能。

    批量消費實現(xiàn)步驟:

    1、重新創(chuàng)建一份新的消費者配置,配置為一次拉取 10 條消息

    2、創(chuàng)建一個監(jiān)聽容器工廠,命名為:batchContainerFactory,設(shè)置其為批量消費并設(shè)置并發(fā)量為 5,這個并發(fā)量根據(jù)分區(qū)數(shù)決定,必須小于等于分區(qū)數(shù),否則會有線程一直處于空閑狀態(tài)。

    3、創(chuàng)建一個分區(qū)數(shù)為 8 的 Topic。

    4、創(chuàng)建監(jiān)聽方法,設(shè)置消費 id 為 “batchConsumer”,clientID 前綴為“batch”,監(jiān)聽“batch”,使用“batchContainerFactory” 工廠創(chuàng)建該監(jiān)聽容器。

    @Component
    
    public class BatchListener {
        private static final Logger log= LoggerFactory.getLogger(BatchListener.class);
        private Map consumerProps() {
    
            Map props = new HashMap<>();
    
            props.put(ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");
    
            props.put(ConsumerConfig.ENABLE_AUTO_COMMIT_CONFIG, true);
    
            props.put(ConsumerConfig.AUTO_COMMIT_INTERVAL_MS_CONFIG, "1000");
    
            props.put(ConsumerConfig.SESSION_TIMEOUT_MS_CONFIG, "15000");
    
            //一次拉取消息數(shù)量
    
            props.put(ConsumerConfig.MAX_POLL_RECORDS_CONFIG, "10");
    
            props.put(ConsumerConfig.KEY_DESERIALIZER_CLASS_CONFIG,
    
                    NumberDeserializers.IntegerDeserializer.class);
    
            props.put(ConsumerConfig.VALUE_DESERIALIZER_CLASS_CONFIG,
    
                    StringDeserializer.class);
    
            return props;
    
        }
        @Bean("batchContainerFactory")
    
        public ConcurrentKafkaListenerContainerFactory listenerContainer() {
    
            ConcurrentKafkaListenerContainerFactory container
    
                    = new ConcurrentKafkaListenerContainerFactory();
    
            container.setConsumerFactory(new DefaultKafkaConsumerFactory(consumerProps()));
    
            //設(shè)置并發(fā)量,小于或等于Topic的分區(qū)數(shù)
    
            container.setConcurrency(5);
    
            //必須 設(shè)置為批量監(jiān)聽
    
            container.setBatchListener(true);
    
            return container;
    
        }
        @Bean
    
        public NewTopic batchTopic() {
    
            return new NewTopic("topic.batch", 8, (short) 1);
    
        }
        @KafkaListener(id = "batchConsumer",clientIdPrefix = "batch"
    
                ,topics = {"topic.batch"},containerFactory = "batchContainerFactory")
    
        public void batchListener(List data) {
    
            log.info("topic.batch  receive : ");
    
            for (String s : data) {
    
                log.info(  s);
    
            }
    
        }
    
    }

    監(jiān)聽 Topic 中指定的分區(qū)

    使用 @KafkaListener 注解的 topicPartitions 屬性監(jiān)聽不同的 partition 分區(qū)。

    @TopicPartition:topic-- 需要監(jiān)聽的 Topic 的名稱,partitions &ndash; 需要監(jiān)聽 Topic 的分區(qū) id。

    partitionOffsets &ndash; 可以設(shè)置從某個偏移量開始監(jiān)聽,@PartitionOffset:partition &ndash; 分區(qū) Id,非數(shù)組,initialOffset &ndash; 初始偏移量。

    @Bean
    
    public NewTopic batchWithPartitionTopic() {
    
        return new NewTopic("topic.batch.partition", 8, (short) 1);
    
    }
    @KafkaListener(id = "batchWithPartition",clientIdPrefix = "bwp",containerFactory = "batchContainerFactory",
    
            topicPartitions = {
    
                    @TopicPartition(topic = "topic.batch.partition",partitions = {"1","3"}),
    
                    @TopicPartition(topic = "topic.batch.partition",partitions = {"0","4"},
    
                            partitionOffsets = @PartitionOffset(partition = "2",initialOffset = "100"))
    
            }
    
    )
    
    public void batchListenerWithPartition(List data) {
    
        log.info("topic.batch.partition  receive : ");
    
        for (String s : data) {
    
            log.info(s);
    
        }
    
    }

    注解方式獲取消息頭及消息體

    當你接收的消息包含請求頭,以及你監(jiān)聽方法需要獲取該消息非常多的字段時可以通過這種方式。。這里使用的是默認的監(jiān)聽容器工廠創(chuàng)建的,如果你想使用批量消費,把對應(yīng)的類型改為 List 即可,比如 List data , List key。

    @Payload:獲取的是消息的消息體,也就是發(fā)送內(nèi)容

    @Header(KafkaHeaders.RECEIVED_MESSAGE_KEY):獲取發(fā)送消息的 key

    @Header(KafkaHeaders.RECEIVED_PARTITION_ID):獲取當前消息是從哪個分區(qū)中監(jiān)聽到的

    @Header(KafkaHeaders.RECEIVED_TOPIC):獲取監(jiān)聽的 TopicName

    @Header(KafkaHeaders.RECEIVED_TIMESTAMP):獲取時間戳

    @KafkaListener(id = "params", topics = "topic.params")
    
    public void otherListener(@Payload String data,
    
                             @Header(KafkaHeaders.RECEIVED_MESSAGE_KEY) Integer key,
    
                             @Header(KafkaHeaders.RECEIVED_PARTITION_ID) int partition,
    
                             @Header(KafkaHeaders.RECEIVED_TOPIC) String topic,
    
                             @Header(KafkaHeaders.RECEIVED_TIMESTAMP) long ts) {
    
        log.info("topic.params receive : \n"+
    
                "data : "+data+"\n"+
    
                "key : "+key+"\n"+
    
                "partitionId : "+partition+"\n"+
    
                "topic : "+topic+"\n"+
    
                "timestamp : "+ts+"\n"
    
        );
    
    }

    使用 Ack 機制確認消費

    Kafka 是通過最新保存偏移量進行消息消費的,而且確認消費的消息并不會立刻刪除,所以我們可以重復(fù)的消費未被刪除的數(shù)據(jù),當?shù)谝粭l消息未被確認,而第二條消息被確認的時候,Kafka 會保存第二條消息的偏移量,也就是說第一條消息再也不會被監(jiān)聽器所獲取,除非是根據(jù)第一條消息的偏移量手動獲取。Kafka 的 ack 機制可以有效的確保消費不被丟失。因為自動提交是在 kafka 拉取到數(shù)據(jù)之后就直接提交,這樣很容易丟失數(shù)據(jù),尤其是在需要事物控制的時候。

    使用 Kafka 的 Ack 機制比較簡單,只需簡單的三步即可:

    • 設(shè)置 ENABLE_AUTO_COMMIT_CONFIG=false,禁止自動提交

    • 設(shè)置 AckMode=MANUAL_IMMEDIATE

    • 監(jiān)聽方法加入 Acknowledgment ack 參數(shù)

    4.使用 Consumer.seek 方法,可以指定到某個偏移量的位置

    @Component
    
    public class AckListener {
    
        private static final Logger log = LoggerFactory.getLogger(AckListener.class);
        private Map consumerProps() {
    
            Map props = new HashMap<>();
    
            props.put(ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG, "localhost:9092");
    
            props.put(ConsumerConfig.ENABLE_AUTO_COMMIT_CONFIG, false);
    
            props.put(ConsumerConfig.AUTO_COMMIT_INTERVAL_MS_CONFIG, "1000");
    
            props.put(ConsumerConfig.SESSION_TIMEOUT_MS_CONFIG, "15000");
    
            props.put(ConsumerConfig.KEY_DESERIALIZER_CLASS_CONFIG, IntegerDeserializer.class);
    
            props.put(ConsumerConfig.VALUE_DESERIALIZER_CLASS_CONFIG, StringDeserializer.class);
    
            return props;
    
        }
        @Bean("ackContainerFactory")
    
        public ConcurrentKafkaListenerContainerFactory ackContainerFactory() {
    
            ConcurrentKafkaListenerContainerFactory factory = new ConcurrentKafkaListenerContainerFactory();
    
            factory.setConsumerFactory(new DefaultKafkaConsumerFactory(consumerProps()));
    
            factory.getContainerProperties().setAckMode(AbstractMessageListenerContainer.AckMode.MANUAL_IMMEDIATE);
    
            factory.setConsumerFactory(new DefaultKafkaConsumerFactory(consumerProps()));
    
            return factory;
    
        }
        @KafkaListener(id = "ack", topics = "topic.ack", containerFactory = "ackContainerFactory")
    
        public void ackListener(ConsumerRecord record, Acknowledgment ack) {
    
            log.info("topic.quick.ack receive : " + record.value());
    
            ack.acknowledge();
    
        }
    
    }

    解決重復(fù)消費

    上一節(jié)中使用 ack 手動提交偏移量時,假如 consumer 掛了重啟,那它將從 committed offset 位置開始重新消費,而不是 consume offset 位置。這也就意味著有可能重復(fù)消費。

    在 0.9 客戶端中,有 3 種 ack 策略:

    策略 1: 自動的,周期性的 ack。

    策略 2:consumer.commitSync(),調(diào)用 commitSync,手動同步 ack。每處理完 1 條消息,commitSync 1 次。

    策略 3:consumer. commitASync(),手動異步 ack。、

    那么使用策略 2,提交每處理完 1 條消息,就發(fā)送一次 commitSync。那這樣是不是就可以解決 “重復(fù)消費” 了呢?如下代碼:

    while (true) {
    
            List buffer = new ArrayList<>();
    
            ConsumerRecords records = consumer.poll(100);
    
            for (ConsumerRecord record : records) {
    
                buffer.add(record);
    
            }
    
            insertIntoDb(buffer);    //消除處理,存到db
    
            consumer.commitSync();   //同步發(fā)送ack
    
            buffer.clear();
    
        }
    
    }

    答案是否定的!因為上面的 insertIntoDb 和 commitSync 做不到原子操作:如果在數(shù)據(jù)處理完成,commitSync 的時候掛了,服務(wù)器再次重啟,消息仍然會重復(fù)消費。

         那么如何解決重復(fù)消費的問題呢?答案是自己保存 committed offset,而不是依賴 kafka 的集群保存 committed offset,把消息的處理和保存 offset 做成一個原子操作,并且對消息加入唯一 id, 進行判重。

    依照官方文檔, 要自己保存偏移量, 需要:

    • enable.auto.commit=false, 禁用自動 ack。

    • 每次取到消息,把對應(yīng)的 offset 存下來。

    • 下次重啟,通過 consumer.seek 函數(shù),定位到自己保存的 offset,從那開始消費。

    • 更進一步處理可以對消息加入唯一 id, 進行判重。

    到此,關(guān)于“spring kafka框架中@KafkaListener注解怎么使用”的學(xué)習就結(jié)束了,希望能夠解決大家的疑惑。理論與實踐的搭配能更好的幫助大家學(xué)習,快去試試吧!若想繼續(xù)學(xué)習更多相關(guān)知識,請繼續(xù)關(guān)注億速云網(wǎng)站,小編會繼續(xù)努力為大家?guī)砀鄬嵱玫奈恼拢?/p>

    向AI問一下細節(jié)

    免責聲明:本站發(fā)布的內(nèi)容(圖片、視頻和文字)以原創(chuàng)、轉(zhuǎn)載和分享為主,文章觀點不代表本網(wǎng)站立場,如果涉及侵權(quán)請聯(lián)系站長郵箱:is@yisu.com進行舉報,并提供相關(guān)證據(jù),一經(jīng)查實,將立刻刪除涉嫌侵權(quán)內(nèi)容。

    AI