Skip navigation links
Spring for Apache Kafka
  • Overview
  • Package
  • Class
  • Use
  • Tree
  • Deprecated
  • Index
  • Help

Deprecated API

Contents

  • Terminally Deprecated
  • Interfaces
  • Classes
  • Enum Classes
  • Methods
  • Constructors
  • Annotation Interface Elements
  • Terminally Deprecated Elements
    Element
    Description
    org.springframework.kafka.config.AbstractKafkaListenerContainerFactory.setBatchErrorHandler(BatchErrorHandler)
    in favor of AbstractKafkaListenerContainerFactory.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.config.AbstractKafkaListenerContainerFactory.setErrorHandler(ErrorHandler)
    in favor of AbstractKafkaListenerContainerFactory.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.core.DefaultKafkaProducerFactory.isProducerPerConsumerPartition()
    no longer necessary because org.springframework.kafka.listener.ContainerProperties.EOSMode#V1 is no longer supported.
    org.springframework.kafka.core.DefaultKafkaProducerFactory.setProducerPerConsumerPartition(boolean)
    no longer necessary because org.springframework.kafka.listener.ContainerProperties.EOSMode#V1 is no longer supported.
    org.springframework.kafka.core.KafkaOperations2
    no longer needed; use KafkaOperations.
    org.springframework.kafka.core.ProducerFactory.closeProducerFor(String)
    - no longer needed.
    org.springframework.kafka.core.ProducerFactory.isProducerPerConsumerPartition()
    no longer necessary because org.springframework.kafka.listener.ContainerProperties.EOSMode#V1 is no longer supported.
    org.springframework.kafka.listener.AbstractMessageListenerContainer.getGenericErrorHandler()
    in favor of AbstractMessageListenerContainer.getCommonErrorHandler()
    org.springframework.kafka.listener.AbstractMessageListenerContainer.setBatchErrorHandler(BatchErrorHandler)
    in favor of AbstractMessageListenerContainer.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.listener.AbstractMessageListenerContainer.setErrorHandler(ErrorHandler)
    in favor of AbstractMessageListenerContainer.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.listener.AbstractMessageListenerContainer.setGenericErrorHandler(GenericErrorHandler<?>)
    in favor of AbstractMessageListenerContainer.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.listener.BatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.CommonContainerStoppingErrorHandler.remainingRecords()
    org.springframework.kafka.listener.CommonErrorHandler.handleRecord(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer)
    in favor of CommonErrorHandler.handleOne(Exception, ConsumerRecord, Consumer, MessageListenerContainer).
    org.springframework.kafka.listener.CommonErrorHandler.remainingRecords()
    in favor of CommonErrorHandler.seeksAfterHandling().
    org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ConsumerAwareErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ConsumerAwareRecordInterceptor
    - use RecordInterceptor.
    org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ContainerAwareErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.DeadLetterPublishingRecoverer.getHeaderNames()
    since 3.0.9 - provide a supplier instead.
    org.springframework.kafka.listener.DefaultErrorHandler.remainingRecords()
    org.springframework.kafka.listener.ErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.GenericErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.RemainingRecordsErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver(Clock, ApplicationContext)
    org.springframework.kafka.retrytopic.RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, BeanFactory, RetryTopicNamesProviderFactory)
  • Deprecated Interfaces
    Interface
    Description
    org.springframework.kafka.core.KafkaOperations2
    no longer needed; use KafkaOperations.
    org.springframework.kafka.listener.BatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ConsumerAwareBatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ConsumerAwareErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ConsumerAwareRecordInterceptor
    - use RecordInterceptor.
    org.springframework.kafka.listener.ContainerAwareBatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ContainerAwareErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.GenericErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.ListenerInvokingBatchErrorHandler
    in favor of CommonErrorHandler.
    org.springframework.kafka.listener.RemainingRecordsErrorHandler
    in favor of CommonErrorHandler.
  • Deprecated Classes
    Class
    Description
    org.springframework.kafka.streams.HeaderEnricher
    in favor of HeaderEnricherProcessor.
    org.springframework.kafka.streams.messaging.MessagingTransformer
    in favor of MessagingProcessor.
    org.springframework.kafka.transaction.ChainedKafkaTransactionManager
    Refer to the ChainedTransactionManager javadocs.
  • Deprecated Enum Classes
    Enum Class
    Description
    org.springframework.kafka.retrytopic.FixedDelayStrategy
    in favor of SameIntervalTopicReuseStrategy.
  • Deprecated Methods
    Method
    Description
    org.springframework.kafka.annotation.RetryableTopic.fixedDelayTopicStrategy()
    in favor of RetryableTopic.sameIntervalTopicReuseStrategy().
    org.springframework.kafka.config.AbstractKafkaListenerContainerFactory.setBatchErrorHandler(BatchErrorHandler)
    in favor of AbstractKafkaListenerContainerFactory.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.config.AbstractKafkaListenerContainerFactory.setErrorHandler(ErrorHandler)
    in favor of AbstractKafkaListenerContainerFactory.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.config.AbstractKafkaListenerContainerFactory.setMessageConverter(MessageConverter)
    since 2.9.6 in favor of AbstractKafkaListenerContainerFactory.setBatchMessageConverter(BatchMessageConverter) and AbstractKafkaListenerContainerFactory.setRecordMessageConverter(RecordMessageConverter).
    org.springframework.kafka.core.DefaultKafkaProducerFactory.isProducerPerConsumerPartition()
    no longer necessary because org.springframework.kafka.listener.ContainerProperties.EOSMode#V1 is no longer supported.
    org.springframework.kafka.core.DefaultKafkaProducerFactory.setProducerPerConsumerPartition(boolean)
    no longer necessary because org.springframework.kafka.listener.ContainerProperties.EOSMode#V1 is no longer supported.
    org.springframework.kafka.core.ProducerFactory.closeProducerFor(String)
    - no longer needed.
    org.springframework.kafka.core.ProducerFactory.isProducerPerConsumerPartition()
    no longer necessary because org.springframework.kafka.listener.ContainerProperties.EOSMode#V1 is no longer supported.
    org.springframework.kafka.listener.AbstractMessageListenerContainer.getGenericErrorHandler()
    in favor of AbstractMessageListenerContainer.getCommonErrorHandler()
    org.springframework.kafka.listener.AbstractMessageListenerContainer.setBatchErrorHandler(BatchErrorHandler)
    in favor of AbstractMessageListenerContainer.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.listener.AbstractMessageListenerContainer.setErrorHandler(ErrorHandler)
    in favor of AbstractMessageListenerContainer.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.listener.AbstractMessageListenerContainer.setGenericErrorHandler(GenericErrorHandler<?>)
    in favor of AbstractMessageListenerContainer.setCommonErrorHandler(CommonErrorHandler)
    org.springframework.kafka.listener.CommonContainerStoppingErrorHandler.remainingRecords()
    org.springframework.kafka.listener.CommonErrorHandler.handleRecord(Exception, ConsumerRecord<?, ?>, Consumer<?, ?>, MessageListenerContainer)
    in favor of CommonErrorHandler.handleOne(Exception, ConsumerRecord, Consumer, MessageListenerContainer).
    org.springframework.kafka.listener.CommonErrorHandler.remainingRecords()
    in favor of CommonErrorHandler.seeksAfterHandling().
    org.springframework.kafka.listener.DeadLetterPublishingRecoverer.getHeaderNames()
    since 3.0.9 - provide a supplier instead.
    org.springframework.kafka.listener.DefaultErrorHandler.remainingRecords()
    org.springframework.kafka.listener.ErrorHandlingUtils.retryBatch(Exception, ConsumerRecords<?, ?>, Consumer<?, ?>, MessageListenerContainer, Runnable, BackOff, CommonErrorHandler, BiConsumer<ConsumerRecords<?, ?>, Exception>, LogAccessor, KafkaException.Level, List<RetryListener>, BinaryExceptionClassifier)
    in favor of ErrorHandlingUtils.retryBatch(Exception, ConsumerRecords, Consumer, MessageListenerContainer, Runnable, BackOff, CommonErrorHandler, BiConsumer, LogAccessor, org.springframework.kafka.KafkaException.Level, List, BinaryExceptionClassifier, boolean).
    org.springframework.kafka.listener.ListenerUtils.byteArrayToDeserializationException(LogAccessor, byte[])
    in favor of SerializationUtils.getExceptionFromHeader(ConsumerRecord, String, LogAccessor) or SerializationUtils.byteArrayToDeserializationException(LogAccessor, org.apache.kafka.common.header.Header).
    org.springframework.kafka.listener.ListenerUtils.getExceptionFromHeader(ConsumerRecord<?, ?>, String, LogAccessor)
    in favor of SerializationUtils.getExceptionFromHeader(ConsumerRecord, String, LogAccessor).
    org.springframework.kafka.retrytopic.DestinationTopic.isSingleTopicRetry()
    in favor of using DestinationTopic.Type.REUSABLE_RETRY_TOPIC and DestinationTopic.isReusableRetryTopic().
    org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder.useSingleTopicForFixedDelays()
    in favor of RetryTopicConfigurationBuilder.useSingleTopicForSameIntervals().
    org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder.useSingleTopicForFixedDelays(FixedDelayStrategy)
    in favor of RetryTopicConfigurationBuilder.sameIntervalTopicReuseStrategy(SameIntervalTopicReuseStrategy).
  • Deprecated Constructors
    Constructor
    Description
    org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver(Clock, ApplicationContext)
    org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory(String, String, List<Long>, BinaryExceptionClassifier, int, KafkaOperations<?, ?>, FixedDelayStrategy, DltStrategy, TopicSuffixingStrategy, long)
    in favor of DestinationTopicPropertiesFactory(String, String, List, BinaryExceptionClassifier, int, KafkaOperations, DltStrategy, TopicSuffixingStrategy, SameIntervalTopicReuseStrategy, long)
    org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory(String, String, List<Long>, BinaryExceptionClassifier, int, KafkaOperations<?, ?>, FixedDelayStrategy, DltStrategy, TopicSuffixingStrategy, SameIntervalTopicReuseStrategy, long)
    in favor of DestinationTopicPropertiesFactory(String, String, List, BinaryExceptionClassifier, int, KafkaOperations, DltStrategy, TopicSuffixingStrategy, SameIntervalTopicReuseStrategy, long)
    org.springframework.kafka.retrytopic.RetryTopicConfigurer(DestinationTopicProcessor, ListenerContainerFactoryResolver, ListenerContainerFactoryConfigurer, BeanFactory, RetryTopicNamesProviderFactory)
    org.springframework.kafka.support.micrometer.MicrometerHolder(ApplicationContext, String, String, String, Map<String, String>)
    in favor of MicrometerHolder(ApplicationContext, String, String, String, Function).
  • Deprecated Annotation Interface Elements
    Annotation Interface Element
    Description
    org.springframework.kafka.annotation.RetryableTopic.fixedDelayTopicStrategy()
    in favor of RetryableTopic.sameIntervalTopicReuseStrategy().