Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
K
- KAFKA_CLIENT_CONTEXT_NAME - Static variable in class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- 
The key for the kafka client configuration entry.
- KAFKA_CONSUMER_BACK_OFF_MANAGER_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
- 
The bean name of the internally managed Kafka consumer back off manager.
- KAFKA_LISTENER_ANNOTATION_PROCESSOR_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
- 
The bean name of the internally managed Kafka listener annotation processor.
- KAFKA_LISTENER_ENDPOINT_REGISTRY_BEAN_NAME - Static variable in class org.springframework.kafka.config.KafkaListenerConfigUtils
- 
The bean name of the internally managed Kafka listener endpoint registry.
- KafkaAdmin - Class in org.springframework.kafka.core
- 
An admin that delegates to anAdminto create topics defined in the application context.
- KafkaAdmin(Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaAdmin
- 
Create an instance with anAdminbased on the supplied configuration.
- KafkaAdmin.NewTopics - Class in org.springframework.kafka.core
- 
Wrapper for a collection ofNewTopicto facilitate declaring multiple topics as a single bean.
- KafkaAdminOperations - Interface in org.springframework.kafka.core
- 
Provides a number of convenience methods wrappingAdminClient.
- KafkaAvroBeanRegistrationAotProcessor - Class in org.springframework.kafka.aot
- 
Detect and register Avro types for Apache Kafka listeners.
- KafkaAvroBeanRegistrationAotProcessor() - Constructor for class org.springframework.kafka.aot.KafkaAvroBeanRegistrationAotProcessor
- KafkaAwareTransactionManager<K,V> - Interface in org.springframework.kafka.transaction 
- 
A transaction manager that can provide aProducerFactory.
- KafkaBackoffAwareMessageListenerAdapter<K,V> - Class in org.springframework.kafka.listener.adapter 
- 
AAcknowledgingConsumerAwareMessageListenerimplementation that looks for a backoff dueTimestamp header and invokes aKafkaConsumerBackoffManagerinstance that will back off if necessary.
- KafkaBackoffAwareMessageListenerAdapter(MessageListener<K, V>, KafkaConsumerBackoffManager, String, String, Clock) - Constructor for class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
- 
The configuration for this listener adapter.
- KafkaBackoffAwareMessageListenerAdapter(MessageListener<K, V>, KafkaConsumerBackoffManager, String, Clock) - Constructor for class org.springframework.kafka.listener.adapter.KafkaBackoffAwareMessageListenerAdapter
- KafkaBackoffException - Exception in org.springframework.kafka.listener
- 
Exception thrown when the consumer should not yet consume the message due to backOff.
- KafkaBackoffException(String, TopicPartition, String, long) - Constructor for exception org.springframework.kafka.listener.KafkaBackoffException
- 
Constructor with data from the BackOff event.
- kafkaBackOffManagerFactory(ListenerContainerRegistry, ApplicationContext) - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
- 
Create theKafkaBackOffManagerFactorythat will be used to create theKafkaConsumerBackoffManagerinstance used to back off the partitions.
- KafkaBackOffManagerFactory - Interface in org.springframework.kafka.listener
- 
Creates aKafkaBackOffManagerFactoryinstance.
- KafkaBootstrapConfiguration - Class in org.springframework.kafka.annotation
- 
AnImportBeanDefinitionRegistrarclass that registers aKafkaListenerAnnotationBeanPostProcessorbean capable of processing Spring's @KafkaListenerannotation.
- KafkaBootstrapConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaBootstrapConfiguration
- KafkaConditions - Class in org.springframework.kafka.test.assertj
- 
AssertJ customConditions.
- KafkaConditions.ConsumerRecordKeyCondition<K> - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordKeyValueCondition<K,V> - Class in org.springframework.kafka.test.assertj 
- KafkaConditions.ConsumerRecordPartitionCondition - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordTimestampCondition - Class in org.springframework.kafka.test.assertj
- KafkaConditions.ConsumerRecordValueCondition<V> - Class in org.springframework.kafka.test.assertj
- kafkaConsumerBackoffManager(ApplicationContext, ListenerContainerRegistry, ObjectProvider<RetryTopicComponentFactory>, RetryTopicSchedulerWrapper, TaskScheduler) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationSupport
- 
Create theKafkaConsumerBackoffManagerinstance that will be used to back off partitions.
- KafkaConsumerBackoffManager - Interface in org.springframework.kafka.listener
- 
Interface for backing off aMessageListenerContaineruntil a given dueTimestamp, if such timestamp is in the future.
- KafkaConsumerBackoffManager.Context - Class in org.springframework.kafka.listener
- 
Provides the state that will be used for backing off.
- KafkaEvent - Class in org.springframework.kafka.event
- 
Base class for events.
- KafkaEvent(Object, Object) - Constructor for class org.springframework.kafka.event.KafkaEvent
- KafkaException - Exception in org.springframework.kafka
- 
The Spring for Apache Kafka specificNestedRuntimeExceptionimplementation.
- KafkaException(String) - Constructor for exception org.springframework.kafka.KafkaException
- 
Construct an instance with the provided properties.
- KafkaException(String, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
- 
Construct an instance with the provided properties.
- KafkaException(String, KafkaException.Level, Throwable) - Constructor for exception org.springframework.kafka.KafkaException
- 
Construct an instance with the provided properties.
- KafkaException.Level - Enum Class in org.springframework.kafka
- 
The log level forKafkaException.
- KafkaExceptionLogLevelAware - Class in org.springframework.kafka.listener
- 
A top level abstract class for classes that can be configured with aKafkaException.Level.
- KafkaExceptionLogLevelAware() - Constructor for class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
- KafkaHandler - Annotation Interface in org.springframework.kafka.annotation
- 
Annotation that marks a method to be the target of a Kafka message listener within a class that is annotated withKafkaListener.
- KafkaHeaderMapper - Interface in org.springframework.kafka.support
- 
Header mapper for Apache Kafka.
- KafkaHeaders - Class in org.springframework.kafka.support
- 
The Kafka specific message headers constants.
- KafkaHeaders() - Constructor for class org.springframework.kafka.support.KafkaHeaders
- KafkaJaasLoginModuleInitializer - Class in org.springframework.kafka.security.jaas
- 
Contains properties for setting up anAppConfigurationEntrythat can be used for the Kafka client.
- KafkaJaasLoginModuleInitializer() - Constructor for class org.springframework.kafka.security.jaas.KafkaJaasLoginModuleInitializer
- KafkaJaasLoginModuleInitializer.ControlFlag - Enum Class in org.springframework.kafka.security.jaas
- 
Control flag values for login configuration.
- KafkaListener - Annotation Interface in org.springframework.kafka.annotation
- 
Annotation that marks a method to be the target of a Kafka message listener on the specified topics.
- KafkaListenerAnnotationBeanPostProcessor<K,V> - Class in org.springframework.kafka.annotation 
- 
Bean post-processor that registers methods annotated withKafkaListenerto be invoked by a Kafka message listener container created under the covers by aKafkaListenerContainerFactoryaccording to the parameters of the annotation.
- KafkaListenerAnnotationBeanPostProcessor() - Constructor for class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- KafkaListenerAnnotationBeanPostProcessor.AnnotationEnhancer - Interface in org.springframework.kafka.annotation
- 
Post processes each set of annotation attributes.
- KafkaListenerConfigurationSelector - Class in org.springframework.kafka.annotation
- 
ADeferredImportSelectorimplementation with the lowest order to import aKafkaBootstrapConfigurationas late as possible.
- KafkaListenerConfigurationSelector() - Constructor for class org.springframework.kafka.annotation.KafkaListenerConfigurationSelector
- KafkaListenerConfigurer - Interface in org.springframework.kafka.annotation
- 
Optional interface to be implemented by Spring managed bean willing to customize how Kafka listener endpoints are configured.
- KafkaListenerConfigUtils - Class in org.springframework.kafka.config
- 
Configuration constants for internal sharing across subpackages.
- KafkaListenerConfigUtils() - Constructor for class org.springframework.kafka.config.KafkaListenerConfigUtils
- KafkaListenerContainerFactory<C extends MessageListenerContainer> - Interface in org.springframework.kafka.config
- 
Factory forMessageListenerContainers.
- KafkaListenerEndpoint - Interface in org.springframework.kafka.config
- 
Model for a Kafka listener endpoint.
- KafkaListenerEndpointRegistrar - Class in org.springframework.kafka.config
- 
Helper bean for registeringKafkaListenerEndpointwith aKafkaListenerEndpointRegistry.
- KafkaListenerEndpointRegistrar() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
- KafkaListenerEndpointRegistry - Class in org.springframework.kafka.config
- 
Creates the necessaryMessageListenerContainerinstances for the registered endpoints.
- KafkaListenerEndpointRegistry() - Constructor for class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- KafkaListenerErrorHandler - Interface in org.springframework.kafka.listener
- 
An error handler which is called when a@KafkaListenermethod throws an exception.
- KafkaListenerObservation - Enum Class in org.springframework.kafka.support.micrometer
- 
Spring for Apache Kafka Observation for listeners.
- KafkaListenerObservation.DefaultKafkaListenerObservationConvention - Class in org.springframework.kafka.support.micrometer
- 
DefaultKafkaListenerObservationConventionfor Kafka listener key values.
- KafkaListenerObservation.ListenerHighCardinalityTags - Enum Class in org.springframework.kafka.support.micrometer
- 
High cardinality tags.
- KafkaListenerObservation.ListenerLowCardinalityTags - Enum Class in org.springframework.kafka.support.micrometer
- 
Low cardinality tags.
- KafkaListenerObservationConvention - Interface in org.springframework.kafka.support.micrometer
- 
ObservationConventionfor Kafka listener key values.
- KafkaListeners - Annotation Interface in org.springframework.kafka.annotation
- 
Container annotation that aggregates severalKafkaListenerannotations.
- KafkaMatchers - Class in org.springframework.kafka.test.hamcrest
- 
HamcrestMatchers utilities.
- KafkaMatchers.ConsumerRecordKeyMatcher<K> - Class in org.springframework.kafka.test.hamcrest
- KafkaMatchers.ConsumerRecordPartitionMatcher - Class in org.springframework.kafka.test.hamcrest
- KafkaMatchers.ConsumerRecordTimestampMatcher - Class in org.springframework.kafka.test.hamcrest
- KafkaMatchers.ConsumerRecordValueMatcher<V> - Class in org.springframework.kafka.test.hamcrest
- KafkaMessageHandlerMethodFactory - Class in org.springframework.kafka.listener.adapter
- 
Extension of theDefaultMessageHandlerMethodFactoryfor Spring Kafka requirements.
- KafkaMessageHandlerMethodFactory() - Constructor for class org.springframework.kafka.listener.adapter.KafkaMessageHandlerMethodFactory
- KafkaMessageHeaderAccessor - Class in org.springframework.kafka.support
- 
A header accessor to provide convenient access to certain headers in a type specific manner.
- KafkaMessageHeaderAccessor(Message<?>) - Constructor for class org.springframework.kafka.support.KafkaMessageHeaderAccessor
- 
Construct an instance for the provided message.
- KafkaMessageHeaders - Class in org.springframework.kafka.support.converter
- 
Overload of message headers configurable for adding id and timestamp headers.
- KafkaMessageListenerContainer<K,V> - Class in org.springframework.kafka.listener 
- 
Single-threaded Message listener container using the JavaConsumersupporting auto-partition assignment or user-configured assignment.
- KafkaMessageListenerContainer(ConsumerFactory<? super K, ? super V>, ContainerProperties) - Constructor for class org.springframework.kafka.listener.KafkaMessageListenerContainer
- 
Construct an instance with the supplied configuration properties.
- KafkaMetricsSupport<C> - Class in org.springframework.kafka.core
- 
An abstract class to manageKafkaClientMetrics.
- KafkaMetricsSupport(MeterRegistry) - Constructor for class org.springframework.kafka.core.KafkaMetricsSupport
- 
Construct an instance with the provided registry.
- KafkaMetricsSupport(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.core.KafkaMetricsSupport
- 
Construct an instance with the providedMeterRegistryand tags.
- KafkaMetricsSupport(MeterRegistry, List<Tag>, TaskScheduler) - Constructor for class org.springframework.kafka.core.KafkaMetricsSupport
- 
Construct an instance with the providedMeterRegistry, tags andTaskScheduler.
- KafkaMetricsSupport(MeterRegistry, TaskScheduler) - Constructor for class org.springframework.kafka.core.KafkaMetricsSupport
- 
Construct an instance with the providedMeterRegistryandTaskScheduler.
- KafkaNull - Class in org.springframework.kafka.support
- 
This class represents NULL Kafka payload.
- KafkaNullAwarePayloadArgumentResolver - Class in org.springframework.kafka.listener.adapter
- KafkaOperations<K,V> - Interface in org.springframework.kafka.core 
- 
The basic Kafka operations contract returningCompletableFutures.
- KafkaOperations.OperationsCallback<K,V, T> - Interface in org.springframework.kafka.core 
- 
A callback for executing arbitrary operations on theKafkaOperations.
- KafkaOperations.ProducerCallback<K,V, T> - Interface in org.springframework.kafka.core 
- 
A callback for executing arbitrary operations on theProducer.
- kafkaPorts(int...) - Method in interface org.springframework.kafka.test.EmbeddedKafkaBroker
- 
Set explicit ports on which the kafka brokers will listen.
- kafkaPorts(int...) - Method in class org.springframework.kafka.test.EmbeddedKafkaKraftBroker
- 
IMPORTANT: It is not possible to configure custom ports when using KRaft based EmbeddedKafka.
- kafkaPorts(int...) - Method in class org.springframework.kafka.test.EmbeddedKafkaZKBroker
- 
Set explicit ports on which the kafka brokers will listen.
- kafkaPorts(int...) - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
- 
Set explicit ports on which the kafka brokers will listen.
- KafkaProducerException - Exception in org.springframework.kafka.core
- 
Exceptions when producing.
- KafkaProducerException(ProducerRecord<?, ?>, String, Throwable) - Constructor for exception org.springframework.kafka.core.KafkaProducerException
- 
Construct an instance with the provided properties.
- KafkaRecordReceiverContext - Class in org.springframework.kafka.support.micrometer
- 
ReceiverContextforConsumerRecords.
- KafkaRecordReceiverContext(ConsumerRecord<?, ?>, String, String, String, Supplier<String>) - Constructor for class org.springframework.kafka.support.micrometer.KafkaRecordReceiverContext
- 
Construct a kafka record receiver context.
- KafkaRecordReceiverContext(ConsumerRecord<?, ?>, String, Supplier<String>) - Constructor for class org.springframework.kafka.support.micrometer.KafkaRecordReceiverContext
- 
Construct a kafka record receiver context.
- KafkaRecordSenderContext - Class in org.springframework.kafka.support.micrometer
- 
SenderContextforProducerRecords.
- KafkaRecordSenderContext(ProducerRecord<?, ?>, String, Supplier<String>) - Constructor for class org.springframework.kafka.support.micrometer.KafkaRecordSenderContext
- KafkaReplyTimeoutException - Exception in org.springframework.kafka.requestreply
- 
Exception when a reply is not received within a timeout.
- KafkaReplyTimeoutException(String) - Constructor for exception org.springframework.kafka.requestreply.KafkaReplyTimeoutException
- KafkaResourceFactory - Class in org.springframework.kafka.core
- 
Base class for consumer/producer/admin creators.
- KafkaResourceFactory() - Constructor for class org.springframework.kafka.core.KafkaResourceFactory
- KafkaResourceHolder<K,V> - Class in org.springframework.kafka.core 
- 
Kafka resource holder, wrapping a Kafka producer.
- KafkaResourceHolder(Producer<K, V>, Duration) - Constructor for class org.springframework.kafka.core.KafkaResourceHolder
- 
Construct an instance for the producer.
- KafkaRuntimeHints - Class in org.springframework.kafka.aot
- 
RuntimeHintsRegistrarfor Spring for Apache Kafka.
- KafkaRuntimeHints() - Constructor for class org.springframework.kafka.aot.KafkaRuntimeHints
- KafkaStreamBrancher<K,V> - Class in org.springframework.kafka.support 
- 
Provides a method-chaining way to buildbranchesin Kafka Streams processor topology.
- KafkaStreamBrancher() - Constructor for class org.springframework.kafka.support.KafkaStreamBrancher
- KafkaStreamsConfiguration - Class in org.springframework.kafka.config
- 
Wrapper forStreamsBuilderproperties.
- KafkaStreamsConfiguration(Map<String, Object>) - Constructor for class org.springframework.kafka.config.KafkaStreamsConfiguration
- KafkaStreamsCustomizer - Interface in org.springframework.kafka.config
- 
Callback interface that can be used to configureKafkaStreamsdirectly.
- KafkaStreamsDefaultConfiguration - Class in org.springframework.kafka.annotation
- 
@Configurationclass that registers aStreamsBuilderFactoryBeanifStreamsConfigwith the nameKafkaStreamsDefaultConfiguration.DEFAULT_STREAMS_CONFIG_BEAN_NAMEis present in the application context.
- KafkaStreamsDefaultConfiguration() - Constructor for class org.springframework.kafka.annotation.KafkaStreamsDefaultConfiguration
- KafkaStreamsInfrastructureCustomizer - Interface in org.springframework.kafka.config
- 
A customizer for infrastructure components such as theStreamsBuilderandTopology.
- KafkaStreamsInteractiveQueryService - Class in org.springframework.kafka.streams
- 
Provide a wrapper API around the interactive query stores in Kafka Streams.
- KafkaStreamsInteractiveQueryService(StreamsBuilderFactoryBean) - Constructor for class org.springframework.kafka.streams.KafkaStreamsInteractiveQueryService
- 
Construct an instance for querying state stores from the KafkaStreams in theStreamsBuilderFactoryBean.
- KafkaStreamsMicrometerListener - Class in org.springframework.kafka.streams
- 
Creates aKafkaStreamsMetricsfor theKafkaStreams.
- KafkaStreamsMicrometerListener(MeterRegistry) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- 
Construct an instance with the provided registry.
- KafkaStreamsMicrometerListener(MeterRegistry, List<Tag>) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- 
Construct an instance with the provided registry and tags.
- KafkaStreamsMicrometerListener(MeterRegistry, List<Tag>, TaskScheduler) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- 
Construct an instance with the provided registry, tags and task scheduler.
- KafkaStreamsMicrometerListener(MeterRegistry, TaskScheduler) - Constructor for class org.springframework.kafka.streams.KafkaStreamsMicrometerListener
- 
Construct an instance with the provided registry and task scheduler.
- kafkaTemplate() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
- 
The bean name of theKafkaTemplatebean that will be used to forward the message to the retry and Dlt topics.
- KafkaTemplate<K,V> - Class in org.springframework.kafka.core 
- 
A template for executing high-level operations.
- KafkaTemplate(ProducerFactory<K, V>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
- 
Create an instance using the supplied producer factory and autoFlush false.
- KafkaTemplate(ProducerFactory<K, V>, boolean) - Constructor for class org.springframework.kafka.core.KafkaTemplate
- 
Create an instance using the supplied producer factory and autoFlush setting.
- KafkaTemplate(ProducerFactory<K, V>, boolean, Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
- 
Create an instance using the supplied producer factory and autoFlush setting.
- KafkaTemplate(ProducerFactory<K, V>, Map<String, Object>) - Constructor for class org.springframework.kafka.core.KafkaTemplate
- 
Create an instance using the supplied producer factory and properties, with autoFlush false.
- KafkaTemplateObservation - Enum Class in org.springframework.kafka.support.micrometer
- 
Spring for Apache Kafka Observation forKafkaTemplate.
- KafkaTemplateObservation.DefaultKafkaTemplateObservationConvention - Class in org.springframework.kafka.support.micrometer
- 
DefaultKafkaTemplateObservationConventionfor Kafka template key values.
- KafkaTemplateObservation.TemplateLowCardinalityTags - Enum Class in org.springframework.kafka.support.micrometer
- 
Low cardinality tags.
- KafkaTemplateObservationConvention - Interface in org.springframework.kafka.support.micrometer
- 
ObservationConventionfor Kafka template key values.
- KafkaTestUtils - Class in org.springframework.kafka.test.utils
- 
Kafka testing utilities.
- KafkaTransactionManager<K,V> - Class in org.springframework.kafka.transaction 
- 
PlatformTransactionManagerimplementation for a single KafkaProducerFactory.
- KafkaTransactionManager(ProducerFactory<K, V>) - Constructor for class org.springframework.kafka.transaction.KafkaTransactionManager
- 
Create a new KafkaTransactionManager, given a ProducerFactory.
- KafkaUtils - Class in org.springframework.kafka.support
- 
Utility methods.
- key(K) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- KEY - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
The header containing the record key when sending data to Kafka.
- KEY_DEFAULT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- 
Default header name for key type information.
- KEY_DEFAULT_CONTENT_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- 
Default header name for key container object contents type information.
- KEY_DEFAULT_KEY_CLASSID_FIELD_NAME - Static variable in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- 
Default header name for key map key type information.
- KEY_DEFAULT_TYPE - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- 
Kafka config property for the default key type if no header.
- KEY_DESERIALIZER_CLASS - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- 
Property name for the delegate key deserializer.
- KEY_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.KafkaUtils
- 
Header name for deserialization exceptions.
- KEY_DESERIALIZER_EXCEPTION_HEADER - Static variable in class org.springframework.kafka.support.serializer.SerializationUtils
- 
Header name for deserialization exceptions.
- KEY_EXCEPTION_FQCN - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
Exception class name for a record published sent to another topic with a key deserialization exception.
- KEY_EXCEPTION_MESSAGE - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
Exception message for a record published to another topic with a key deserialization exception.
- KEY_EXCEPTION_STACKTRACE - Static variable in class org.springframework.kafka.support.KafkaHeaders
- 
Exception stack trace for a record published to another topic with a key deserialization exception.
- KEY_FUNCTION - Static variable in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- 
Supplier for a T when deserialization fails.
- KEY_PARSER - Static variable in class org.springframework.kafka.support.serializer.ParseStringDeserializer
- 
Property for the key parser method.
- KEY_SERIALIZATION_SELECTOR - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
- 
Name of the header containing the serialization selector for keys.
- KEY_SERIALIZATION_SELECTOR_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingSerializer
- 
Name of the configuration property containing the serialization selector map for keys with formatselector:class,....
- KEY_SERIALIZATION_TOPIC_CONFIG - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- 
Name of the configuration property containing the serialization topic pattern map for keys with formatpattern:class,....
- KEY_SERIALIZATION_TOPIC_DEFAULT - Static variable in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
- 
Name of the default delegate for keys when no topic name match is fount.
- KEY_TYPE - Static variable in class org.springframework.kafka.support.serializer.ToStringSerializer
- 
Header for the type of key.
- KEY_TYPE_METHOD - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- 
A method name to determine theJavaTypeto deserialize the key to: 'com.Foo.deserialize'.
- keyDeserializer(boolean) - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
- 
Set to true if this deserializer is to be used as a key deserializer when configuring outside of Kafka.
- keyExceptionFqcn(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
- 
Sets the name of the header that will be used to store the keyExceptionFqcn of the original record.
- keyExceptionMessage(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
- 
Sets the name of the header that will be used to store the keyExceptionMessage of the original record.
- keyExceptionStacktrace(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.ExceptionInfo
- 
Sets the name of the header that will be used to store the keyExceptionStacktrace of the original record.
- keyValue(K, V) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- KotlinAwareInvocableHandlerMethod - Class in org.springframework.kafka.listener.adapter
- 
AnInvocableHandlerMethodextension for supporting Kotlinsuspendfunction.
- KotlinAwareInvocableHandlerMethod(Object, Method) - Constructor for class org.springframework.kafka.listener.adapter.KotlinAwareInvocableHandlerMethod
- kraft() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
- 
Use KRaft instead of Zookeeper; default false.
- KRAFT_PROPERTY_NAME - Static variable in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
- 
The number of partitions on topics to create on the embedded broker(s).
- KSTREAM_DESERIALIZATION_RECOVERER - Static variable in class org.springframework.kafka.streams.RecoveringDeserializationExceptionHandler
- 
Property name for configuring the recoverer using properties.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form