Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
P
- parentOrThis() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return this or a parent container if this has a parent.
- parentOrThis() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- parseBooleanProperty(String) - Static method in class org.springframework.kafka.test.utils.JUnitUtils
-
Return the parsed value if the provided property exists in the environment or system properties.
- PARSER_CONTEXT - Static variable in class org.springframework.kafka.listener.adapter.AdapterUtils
-
Parser context for runtime SpEL using ! as the template prefix.
- ParseStringDeserializer<T> - Class in org.springframework.kafka.support.serializer
-
Generic
Deserializer
for deserialization of entity from itsString
representation received from Kafka (a.k.a parsing). - ParseStringDeserializer() - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Construct an instance with no parser function; a static method name must be provided in the consumer config
ParseStringDeserializer.KEY_PARSER
orParseStringDeserializer.VALUE_PARSER
properties. - ParseStringDeserializer(BiFunction<String, Headers, T>) - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Construct an instance with the supplied parser function.
- ParseStringDeserializer(Function<String, T>) - Constructor for class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Construct an instance with the supplied parser function.
- PARTIAL_RESULTS_AFTER_TIMEOUT_TOPIC - Static variable in class org.springframework.kafka.requestreply.AggregatingReplyingKafkaTemplate
-
Pseudo topic name for the "outer"
ConsumerRecord
that has the aggregated results in its value after a timeout. - partition() - Element in annotation interface org.springframework.kafka.annotation.PartitionOffset
-
The partition within the topic to listen on.
- partition() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- partition(int) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- PARTITION - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The partition from which the failed record was received.
- PARTITION - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the topic partition when sending data to Kafka.
- partitionHeader(String) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Builder.Original
-
Sets the name of the header that will be used to store the partition of the original record.
- PartitionOffset - Annotation Interface in org.springframework.kafka.annotation
-
Used to add partition/initial offset information to a
KafkaListener
. - partitionOffsets() - Element in annotation interface org.springframework.kafka.annotation.TopicPartition
-
The partitions with initial offsets within the topic.
- partitions() - Element in annotation interface org.springframework.kafka.annotation.TopicPartition
-
The partitions within the topic.
- partitions() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
- partitions(int) - Method in class org.springframework.kafka.config.TopicBuilder
-
Set the number of partitions (default broker 'num.partitions').
- PARTITIONS_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).
- partitionsFor(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- partitionsFor(String) - Method in interface org.springframework.kafka.core.KafkaOperations
-
See
Producer.partitionsFor(String)
. - partitionsFor(String) - Method in class org.springframework.kafka.core.KafkaTemplate
- partitionsFromConsumerFor(String) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- partitionsFromProducerFor(String) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- pause() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- pause() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- pause() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- pause() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Pause this container before the next poll().
- pause(String, Duration) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Pause the listener by given id.
- pause(TopicPartition...) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- pause(MessageListenerContainer, Duration) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Pause the listener by given container instance.
- paused() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- pausePartition(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- pausePartition(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- pausePartition(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Pause this partition before the next poll().
- pausePartition(MessageListenerContainer, TopicPartition, Duration) - Method in class org.springframework.kafka.listener.ListenerContainerPauseService
-
Pause consumption from a given partition for the duration.
- ports() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
-
Set explicit ports on which the kafka brokers will listen.
- PORTS_PROPERTY_NAME - Static variable in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
-
The port(s) to expose embedded broker(s).
- position(TopicPartition) - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaConsumerTemplate
- postProcess(C) - Method in interface org.springframework.kafka.config.ContainerPostProcessor
-
Post processes the container.
- postProcessAfterInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- postProcessBeforeInitialization(Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- PREFIX - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The prefix for Kafka headers.
- primary() - Method in class org.springframework.kafka.core.ABSwitchCluster
-
Use the primary cluster.
- process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
-
Process the remaining records.
- process(List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
- process(Record<K, V>) - Method in class org.springframework.kafka.streams.HeaderEnricherProcessor
- process(Record<Kin, Vin>) - Method in class org.springframework.kafka.streams.messaging.MessagingProcessor
- process(MethodKafkaListenerEndpoint<?, ?>) - Method in interface org.springframework.kafka.retrytopic.RetryTopicConfigurer.EndpointProcessor
- processAheadOfTime(RegisteredBean) - Method in class org.springframework.kafka.aot.KafkaAvroBeanRegistrationAotProcessor
- processAnnotation(String[], Class<?>, RetryableTopic, Object) - Method in class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
- processAnnotation(String[], Method, RetryableTopic, Object) - Method in class org.springframework.kafka.annotation.RetryableTopicAnnotationProcessor
- processBatch(ConsumerRecords<K, V>, List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
-
Process the entire batch of records.
- processBatch(ConsumerRecords<K, V>, List<ConsumerRecord<K, V>>, Consumer<K, V>, MessageListenerContainer, Exception, boolean, ContainerProperties.EOSMode) - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
- processDestinationTopicProperties(Consumer<DestinationTopic.Properties>, DestinationTopicProcessor.Context) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- processDestinationTopicProperties(Consumer<DestinationTopic.Properties>, DestinationTopicProcessor.Context) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicProcessor
-
Process the destination properties.
- processKafkaListener(KafkaListener, Method, Object, String) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- processListener(MethodKafkaListenerEndpoint<?, ?>, KafkaListener, Object, String, String[], TopicPartitionOffset[]) - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- processMainAndRetryListeners(RetryTopicConfigurer.EndpointProcessor, MethodKafkaListenerEndpoint<?, ?>, RetryTopicConfiguration, KafkaListenerEndpointRegistrar, KafkaListenerContainerFactory<?>, String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
-
Entrypoint for creating and configuring the retry and dlt endpoints, as well as the container factory that will create the corresponding listenerContainer.
- processRegisteredDestinations(Consumer<Collection<String>>, DestinationTopicProcessor.Context) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicProcessor
- processRegisteredDestinations(Consumer<Collection<String>>, DestinationTopicProcessor.Context) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicProcessor
-
Process the registered destinations.
- producerAdded(String, Producer<K, V>) - Method in class org.springframework.kafka.core.MicrometerProducerListener
- producerAdded(String, Producer<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory.Listener
-
A new producer was created.
- ProducerFactory<K,
V> - Interface in org.springframework.kafka.core -
The strategy to produce a
Producer
instance(s). - ProducerFactory.Listener<K,
V> - Interface in org.springframework.kafka.core -
Called whenever a producer is added or removed.
- ProducerFactoryUtils - Class in org.springframework.kafka.core
-
Helper class for managing a Spring based Kafka
DefaultKafkaProducerFactory
in particular for obtaining transactional Kafka resources for a given ProducerFactory. - ProducerListener<K,
V> - Interface in org.springframework.kafka.support -
Listener for handling outbound Kafka messages.
- ProducerPostProcessor<K,
V> - Interface in org.springframework.kafka.core -
Called by producer factories to perform post processing on newly created producers.
- producerProps(String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Set up test properties for an
<Integer, String>
producer. - producerProps(EmbeddedKafkaBroker) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Set up test properties for an
<Integer, String>
producer. - producerRemoved(String, Producer<K, V>) - Method in class org.springframework.kafka.core.MicrometerProducerListener
- producerRemoved(String, Producer<K, V>) - Method in interface org.springframework.kafka.core.ProducerFactory.Listener
-
An existing producer was removed.
- ProjectingMessageConverter - Class in org.springframework.kafka.support.converter
-
A
MessageConverter
implementation that uses a Spring DataProjectionFactory
to bind incoming messages to projection interfaces. - ProjectingMessageConverter() - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using aJacksonUtils.enhancedObjectMapper()
by default. - ProjectingMessageConverter(ObjectMapper) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using the givenObjectMapper
. - ProjectingMessageConverter(ObjectMapper, MessagingMessageConverter) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using the givenObjectMapper
. - ProjectingMessageConverter(MessagingMessageConverter) - Constructor for class org.springframework.kafka.support.converter.ProjectingMessageConverter
-
Create a new
ProjectingMessageConverter
using the givenObjectMapper
. - properties - Variable in class org.springframework.kafka.retrytopic.DestinationTopicProcessor.Context
- properties() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
-
Kafka consumer properties; they will supersede any properties with the same name defined in the consumer factory (if the consumer factory supports property overrides).
- Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties with the DLT container starting automatically (if the container factory is so configured).
- Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long, Boolean) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties.
- Properties(long, String, DestinationTopic.Type, int, int, DltStrategy, KafkaOperations<?, ?>, BiPredicate<Integer, Throwable>, long, Boolean, Set<Class<? extends Throwable>>) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties.
- Properties(DestinationTopic.Properties, String, DestinationTopic.Type) - Constructor for class org.springframework.kafka.retrytopic.DestinationTopic.Properties
-
Create an instance with the provided properties with the DLT container starting automatically.
- propertiesFromConsumerPropertyOverrides() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Make any default consumer override properties explicit properties.
- propertyToMethodInvokingFunction(String, Class<P>, ClassLoader) - Static method in class org.springframework.kafka.support.serializer.SerializationUtils
-
Convert a property value (FQCN.methodName) to a
BiFunction
that takes a payload and headers and returns some value. - provide(ListenerMetadata, long) - Method in interface org.springframework.kafka.listener.OffsetAndMetadataProvider
-
Provide an offset and metadata object for the given listener metadata and offset.
- publish(ProducerRecord<Object, Object>, KafkaOperations<Object, Object>, ConsumerRecord<?, ?>) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Override this if you want more than just logging of the send result.
- publishConsumerPausedEvent(Collection<TopicPartition>, String) - Method in interface org.springframework.kafka.listener.ConsumerPauseResumeEventPublisher
-
Publish a consumer paused event.
- publishConsumerPausedEvent(Collection<TopicPartition>, String) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- publishConsumerResumedEvent(Collection<TopicPartition>) - Method in interface org.springframework.kafka.listener.ConsumerPauseResumeEventPublisher
-
Publish a consumer resumed event.
- publishConsumerResumedEvent(Collection<TopicPartition>) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- publishContainerStoppedEvent() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form