Uploaded image for project: 'Kafka'
  1. Kafka
  2. KAFKA-12822 Remove Deprecated APIs of Kafka Streams in 4.0
  3. KAFKA-12829

Remove Deprecated methods can classes of old Processor API

    XMLWordPrintableJSON

Details

    • Sub-task
    • Status: Open
    • Blocker
    • Resolution: Unresolved
    • None
    • 4.0.0
    • streams
    • None

    Description

      The following methods were deprecated in version 2.7:

      • org.apache.kafka.streams.Topology#addProcessor(java.lang.String, org.apache.kafka.streams.processor.ProcessorSupplier, java.lang.String...)
      • org.apache.kafka.streams.Topology#addGlobalStore(org.apache.kafka.streams.state.StoreBuilder<?>, java.lang.String, org.apache.kafka.common.serialization.Deserializer<K>, org.apache.kafka.common.serialization.Deserializer<V>, java.lang.String, java.lang.String, org.apache.kafka.streams.processor.ProcessorSupplier<K,V>)
      • org.apache.kafka.streams.Topology#addGlobalStore(org.apache.kafka.streams.state.StoreBuilder<?>, java.lang.String, org.apache.kafka.streams.processor.TimestampExtractor, org.apache.kafka.common.serialization.Deserializer<K>, org.apache.kafka.common.serialization.Deserializer<V>, java.lang.String, java.lang.String, org.apache.kafka.streams.processor.ProcessorSupplier<K,V>)
      • org.apache.kafka.streams.StreamsBuilder#addGlobalStore(org.apache.kafka.streams.state.StoreBuilder<?>, java.lang.String, org.apache.kafka.streams.kstream.Consumed<K,V>, org.apache.kafka.streams.processor.ProcessorSupplier<K,V>)
      • org.apache.kafka.streams.processor.StateStore#init(org.apache.kafka.streams.processor.ProcessorContext, org.apache.kafka.streams.processor.StateStore)
      • org.apache.kafka.streams.kstream.KStream.process (multiple, taking the old `ProcessorSupplier`)
      • org.apache.kafka.streams.scala.KStream.process (multiple, taking the old `ProcessorSupplier`)

      The following classes were deprecated:

      • org.apache.kafka.streams.processor.{Processor, ProcessorSupplier, ProcessorContext} (note: that `ProcessorContext` is also use by `Transformer` which was also deprecated in 3.3 and can be removed, too)
      • Cf https://issues.apache.org/jira/browse/KAFKA-16339 – both tickets should be worked on together

      Also cf related tickets:

      See KAFKA-10605 and KIP-478.

      Attachments

        Issue Links

          Activity

            People

              Unassigned Unassigned
              jlprat Josep Prat
              Votes:
              0 Vote for this issue
              Watchers:
              4 Start watching this issue

              Dates

                Created:
                Updated: