Uploaded image for project: 'Kafka'
  1. Kafka
  2. KAFKA-13864

Change the visibility of a KafkaProducer and KafkaConsumer constructor

    XMLWordPrintableJSON

Details

    • Improvement
    • Status: Resolved
    • Major
    • Resolution: Won't Do
    • 3.1.0
    • None
    • clients
    • None

    Description

      To allow implementing Spring managed interceptors for producers and consumers,

      https://github.com/spring-projects/spring-kafka/issues/2244

      The following changes should be applied in Kafka

      1. Create 2 new constructors in KafkaProducer

      public KafkaProducer(ProducerConfig config)
      public KafkaProducer(ProducerConfig config, Serializer<K> keySerializer, Serializer<V> valueSerializer) 

      2. Create a new constructor + increase the visibility of an existing constructor in KafkaConsumer

      public KafkaConsumer(ConsumerConfig config)
      public KafkaConsumer(ConsumerConfig config, Deserializer<K> keyDeserializer, Deserializer<V> valueDeserializer)

      3. Create 2 new constructors in TopologyTestDriver

      public TopologyTestDriver(Topology topology, StreamsConfig config)
      public TopologyTestDriver(Topology topology, StreamsConfig config, Instant initialWallClockTime) 

       More details can be found in the related KIP

      https://cwiki.apache.org/confluence/pages/viewpage.action?pageId=211882578

       

      Attachments

        Issue Links

          Activity

            People

              frosiere François Rosière
              frosiere François Rosière
              Votes:
              0 Vote for this issue
              Watchers:
              4 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: