Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
G
- generateValues() - Method in class org.springframework.kafka.retrytopic.BackOffValuesGenerator
- GenericErrorHandler<T> - Interface in org.springframework.kafka.listener
-
Deprecated.
- GenericMessageListener<T> - Interface in org.springframework.kafka.listener
-
Top level interface for listeners.
- GenericMessageListenerContainer<K,
V> - Interface in org.springframework.kafka.listener -
Generic message listener container; adds parameters.
- get() - Method in class org.springframework.kafka.core.ABSwitchCluster
- get() - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture
- get(long, TimeUnit) - Method in class org.springframework.kafka.requestreply.RequestReplyTypedMessageFuture
- getAckCount() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAckMode() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAckTime() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAdviceChain() - Method in class org.springframework.kafka.listener.ContainerProperties
-
A chain of listener
Advice
s. - getAfterRollbackProcessor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return the currently configured
AfterRollbackProcessor
. - getAllListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return all
MessageListenerContainer
instances including those managed by this registry and those declared as beans in the application context. - getAllListenerContainers() - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return all
MessageListenerContainer
instances including those managed by this registry and those declared as beans in the application context. - getApplicationContext() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getApplicationEventPublisher() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Get the event publisher.
- getAssignedPartitions() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getAssignedPartitions() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
-
Return the
TopicPartition
s currently assigned to this container, either explicitly or by Kafka; may be null if not assigned yet. - getAssignedPartitions() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the assigned topics/partitions for this container.
- getAssignedReplyTopicPartitions() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return the topics/partitions assigned to the replying listener container.
- getAssignmentCommitOption() - Method in class org.springframework.kafka.listener.ContainerProperties
- getAssignmentsByClientId() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getAssignmentsByClientId() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- getAssignmentsByClientId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the assigned topics/partitions for this container, by client.id.
- getAuthExceptionRetryInterval() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Get the authentication/authorization retry interval.
- getAutoStartup() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getAutoStartup() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the autoStartup for this endpoint's container.
- getBatchInterceptor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the current batch listener flag for this endpoint, or null if not explicitly set.
- getBatchMessageConverter() - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
-
Return the
BatchMessagingMessageConverter
for this listener, being able to convertMessage
. - getBatchToRecordAdapter() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBean() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- getBean() - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Return the bean for this handler.
- getBean() - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
- getBean(String, Class<T>) - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- getBeanExpressionContext() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBeanFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBeanName() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Return the bean name.
- getBeanResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getBootstrapServers() - Method in class org.springframework.kafka.core.KafkaResourceFactory
- getBroker() - Static method in class org.springframework.kafka.test.condition.EmbeddedKafkaCondition
- getBrokerAddress(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getBrokerAddresses() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getBrokersAsString() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getCache() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getCache(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getCallbacksAndTopics() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Return the currently registered callbacks and their associated
TopicPartition
(s). - getCharset() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper
- getCharset() - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Get the configured charset.
- getCharset() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
-
Get the configured charset.
- getClassIdFieldName() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getClassifier() - Method in class org.springframework.kafka.listener.ExceptionClassifier
-
Return the exception classifier.
- getClassLoader() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getClientId() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the client id.
- getClientIdPrefix() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getClientIdPrefix() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the client id prefix for the container; it will be suffixed by '-n' to provide a unique id when concurrency is used.
- getClientIdPrefix(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the clientId prefix that will override the endpoint's clientId prefix.
- getClientIdPrefix(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getCommitCallback() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the commit callback.
- getCommitLogLevel() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
The level at which to log offset commits.
- getCommitRetries() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
The number of retries allowed when a
RetriableCommitFailedException
is thrown by the consumer when usingConsumerProperties.setSyncCommits(boolean)
set to true. - getCommonErrorHandler() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Get the
CommonErrorHandler
. - getConcurrency() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getConcurrency() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the concurrency for this endpoint's container.
- getConcurrency() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- getConfigurationProperties() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getConfigurationProperties() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConfigurationProperties() - Method in class org.springframework.kafka.core.KafkaAdmin
- getConfigurationProperties() - Method in interface org.springframework.kafka.core.KafkaAdminOperations
-
Get an unmodifiable copy of this admin's configuration.
- getConfigurationProperties() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return an unmodifiable reference to the configuration map for this factory.
- getConsumer() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
Retrieve the consumer.
- getConsumer() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
Retrieve the consumer.
- getConsumerFactory() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
- getConsumerForTimingAdjustment() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getConsumerGroup() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the consumer group.
- getConsumerGroupId() - Static method in class org.springframework.kafka.support.KafkaUtils
-
Get the group id for the consumer bound to this thread.
- getConsumerProperties() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getConsumerProperties() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Get the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- getConsumerRebalanceListener() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the rebalance listener.
- getConsumerStartTimeout() - Method in class org.springframework.kafka.listener.ContainerProperties
- getConsumerTaskExecutor() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the consumer task executor.
- getContainer(Class<T>) - Method in class org.springframework.kafka.event.KafkaEvent
-
Get the container for which the event was published, which will be the parent container if the source that emitted the event is a child container, or the source itself otherwise.
- getContainerProperties() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
-
Obtain the properties template for this factory - set properties as needed and they will be copied to a final properties instance for the endpoint.
- getContainerProperties() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getContainerProperties() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the container properties for this container.
- getContainers() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
-
Return the list of
KafkaMessageListenerContainer
s created by this container. - getContentClassIdFieldName() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getContext() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
- getCorrelationHeaderName() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return the correlation header name.
- getCorrelationId() - Method in class org.springframework.kafka.requestreply.CorrelationKey
- getCurrentOffset(String, String, String, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Get the current offset and metadata for the provided group/topic/partition.
- getCurrentOffset(AdminClient, String, String, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Get the current offset and metadata for the provided group/topic/partition.
- getCustomMethodArgumentResolvers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Return the list of
HandlerMethodArgumentResolver
. - getData() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
Get the data that failed deserialization (value or key).
- getData() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getDefaultPredicate(Collection<T>, Collection<T>) - Method in class org.springframework.kafka.support.AllowDenyCollectionManager
- getDefaultReplyTimeout() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
-
Return the reply timeout used if no replyTimeout is provided in the
ReplyingKafkaTemplate.sendAndReceive(ProducerRecord, Duration)
call. - getDefaultReplyTopicExpression() - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
-
Return the default expression when no SendTo value is present.
- getDefaultTopic() - Method in class org.springframework.kafka.core.KafkaTemplate
-
The default topic for send methods where a topic is not provided.
- getDelegate() - Method in class org.springframework.kafka.listener.adapter.AbstractDelegatingMessageListenerAdapter
- getDelegate() - Method in class org.springframework.kafka.listener.adapter.ConvertingMessageListener
- getDelegate() - Method in interface org.springframework.kafka.listener.DelegatingMessageListener
-
Return the delegate.
- getDelegates() - Method in class org.springframework.kafka.support.CompositeProducerListener
- getDestinationDelay() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationName() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationPartitions() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationTimeout() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getDestinationTopicByName(String) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- getDestinationTopicByName(String) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Returns the
DestinationTopic
instance registered for that topic. - getDestinationTopicProperties() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- getDltFor(String) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- getDltFor(String) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Returns the
DestinationTopic
instance registered as DLT for the given topic, or null if none is found. - getDltHandlerMethod() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfiguration
- getDltSuffix() - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory.DestinationTopicSuffixes
- getDueTimestamp() - Method in exception org.springframework.kafka.listener.KafkaBackoffException
- getDueTimestamp() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getEmbeddedKafka() - Method in class org.springframework.kafka.test.rule.EmbeddedKafkaRule
-
Return an underlying delegator
EmbeddedKafkaBroker
instance. - getEndOffsets(Consumer<?, ?>, String, Integer...) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Return the end offsets of the requested topic/partitions
- getEndpointDescription() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return a description for this endpoint.
- getEndpointDescription() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- getEndpointHandlerMethod(MethodKafkaListenerEndpoint<?, ?>, RetryTopicConfiguration, DestinationTopic.Properties) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurer
- getEndpointId(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the endpoint id that will override the endpoint's current id.
- getEndpointId(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getEndpointRegistry() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Return the
KafkaListenerEndpointRegistry
instance for this registrar, may benull
. - getEosMode() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Get the exactly once semantics mode.
- getException() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getExceptionCauseFqcn() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the exception cause.
- getExceptionFqcn() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the value exception class.
- getExceptionFromHeader(ConsumerRecord<?, ?>, String, LogAccessor) - Static method in class org.springframework.kafka.listener.ListenerUtils
-
Extract a
DeserializationException
from the supplied header name, if present. - getExceptionInfo() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames
-
The header names for the exception headers.
- getExceptionMessage() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the exception message.
- getExceptionStacktrace() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the exception stack trace.
- getFailedProducerRecord() - Method in exception org.springframework.kafka.core.KafkaProducerException
-
Return the failed producer record.
- getFailureTracker() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Return the failed record tracker.
- getFallbackBatchHandler() - Method in class org.springframework.kafka.listener.FailedBatchProcessor
-
Return the fallback batch error handler.
- getGenericErrorHandler() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
-
Deprecated.
- getGroup() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getGroup() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the group of this endpoint or null if not in a group.
- getGroup(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the group that will override the endpoint's group.
- getGroup(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getGroupId() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getGroupId() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the groupId of this endpoint - if present, overrides the
group.id
property of the consumer factory. - getGroupId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getGroupId() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the container's group id.
- getGroupId() - Method in exception org.springframework.kafka.listener.ListenerExecutionFailedException
-
Return the consumer group.id property of the container that threw this exception.
- getGroupId() - Method in interface org.springframework.kafka.listener.ListenerMetadata
-
Return the group id.
- getGroupId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Return the
group.id
property for this container whether specifically set on the container or via a consumer property on the consumer factory. - getGroupId() - Static method in interface org.springframework.kafka.support.converter.MessageConverter
-
Get the thread bound group id.
- getGroupId(KafkaListenerEndpoint) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the groupId that will override the endpoint's groupId.
- getGroupId(KafkaListenerEndpoint) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getHandlerForPayload(Class<? extends Object>) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Determine the
InvocableHandlerMethod
for the provided type. - getHeaderNames() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
Override this if you want different header names to be used in the sent record.
- getHeaders() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
-
Get the headers.
- getHeaders() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getHeaderValue() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- getHost() - Method in class org.springframework.kafka.test.core.BrokerAddress
- getId() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getId() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the id of this endpoint.
- getIdClassMapping() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getIdleBeforeDataMultiplier() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Multiply the
ContainerProperties.setIdleEventInterval(Long)
by this value until at least one record is received. - getIdleBetweenPolls() - Method in class org.springframework.kafka.listener.ContainerProperties
- getIdleEventInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the idle event interval.
- getIdlePartitionEventInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the idle partition event interval.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
How long the container has been idle.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
How long the container was idle.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
How long the partition has been idle.
- getIdleTime() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
How long the partition was idle.
- getIndex() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
-
Return the index in the batch of the failed record.
- getKafkaConsumerProperties() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Get the consumer properties that will be merged with the consumer properties provided by the consumer factory; properties here will supersede any with the same name(s) in the consumer factory.
- getKafkaOperations() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- getKafkaServer(int) - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getKafkaServers() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getKafkaStreams() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Get a managed by this
StreamsBuilderFactoryBean
KafkaStreams
instance. - getKey() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
- getKeyClassIdFieldName() - Method in class org.springframework.kafka.support.mapping.AbstractJavaTypeMapper
- getKeyDeserializer() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return the configured key deserializer (if provided as an object instead of a class name in the properties).
- getKeyDeserializer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getKeyExceptionFqcn() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the key exception class.
- getKeyExceptionMessage() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the key exception message.
- getKeyExceptionStacktrace() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.ExceptionInfo
-
The header name for the key exception stack trace.
- getKeySerializer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getKeySerializer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the configured key serializer (if provided as an object instead of a class name in the properties).
- getKeySerializerSupplier() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getKeySerializerSupplier() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return a supplier for a key serializer.
- getListenerContainer(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return the
MessageListenerContainer
with the specified id ornull
if no such container exists. - getListenerContainer(String) - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the
MessageListenerContainer
with the specified id ornull
if no such container exists. - getListenerContainerIds() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return the ids of the managed
MessageListenerContainer
instance(s). - getListenerContainerIds() - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the ids of the managed
MessageListenerContainer
instance(s). - getListenerContainerRegistry() - Method in class org.springframework.kafka.listener.AbstractKafkaBackOffManagerFactory
- getListenerContainers() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
-
Return the managed
MessageListenerContainer
instance(s). - getListenerContainers() - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the managed
MessageListenerContainer
instance(s). - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
The id of the listener (if
@KafkaListener
) or the container bean name. - getListenerId() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getListenerId() - Method in exception org.springframework.kafka.listener.KafkaBackoffException
- getListenerId() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getListenerId() - Method in interface org.springframework.kafka.listener.ListenerMetadata
-
Return the listener id.
- getListenerId() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
The 'id' attribute of a
@KafkaListener
or the bean name for spring-managed containers. - getListenerIds() - Method in class org.springframework.kafka.listener.ContainerGroup
-
Return the listener ids of the containers in this group.
- getListenerInfo() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getListenerInfo() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Get the listener info to insert in the record header.
- getListenerInfo() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getListenerInfo() - Method in interface org.springframework.kafka.listener.ListenerMetadata
-
Return the listener info.
- getListenerInfo() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
-
Get arbitrary static information that will be added to the
KafkaHeaders.LISTENER_INFO
header of all records. - getListeners() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Get the current list of listeners.
- getListeners() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Get the current list of listeners.
- getListeners() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
-
Get the current list of listeners.
- getListeners() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Get the current list of listeners.
- getListeners() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Get the current list of listeners.
- getLogDir() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- getLogLevel() - Method in class org.springframework.kafka.listener.KafkaExceptionLogLevelAware
-
Set the level at which the exception thrown by this handler is logged.
- getMaxAttemps(int) - Method in class org.springframework.kafka.retrytopic.BackOffValuesGenerator
- getMaxRetries() - Method in class org.springframework.kafka.support.ExponentialBackOffWithMaxRetries
-
Get the max retries.
- getMessage() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
- getMessageConverter() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the message converter.
- getMessageConverter() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Return the
MessagingMessageConverter
for this listener, being able to convertMessage
. - getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
-
Return the configured handler factory.
- getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Return the custom
MessageHandlerMethodFactory
to use, if any. - getMessageHandlerMethodFactory() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
-
Return the
MessageHandlerMethodFactory
. - getMessageListener() - Method in class org.springframework.kafka.listener.ContainerProperties
- getMessagingConverter() - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
- getMethod() - Method in class org.springframework.kafka.config.MethodKafkaListenerEndpoint
- getMethod() - Method in class org.springframework.kafka.support.EndpointHandlerMethod
-
Return the method.
- getMethodAsString(Object) - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
- getMethodName() - Method in class org.springframework.kafka.support.EndpointHandlerMethod
-
Return the method name.
- getMethodNameFor(Object) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
-
Return a string representation of the method that will be invoked for this payload.
- getMicrometerTags() - Method in class org.springframework.kafka.listener.ContainerProperties
- getMonitorInterval() - Method in class org.springframework.kafka.listener.ContainerProperties
- getMsg() - Method in exception org.springframework.kafka.support.converter.ConversionException
-
Return the
Message
, if available. - getName() - Method in class org.springframework.kafka.listener.ContainerGroup
-
Return the group name.
- getNextDestination() - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver.DestinationTopicHolder
- getNextDestinationTopicFor(String) - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
- getNextDestinationTopicFor(String) - Method in interface org.springframework.kafka.retrytopic.DestinationTopicContainer
-
Returns the
DestinationTopic
instance registered as the next destination topic in the chain for the given topic. - getNoPollThreshold() - Method in class org.springframework.kafka.listener.ContainerProperties
- getObjectMapper() - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
-
Return the object mapper.
- getObjectMapper() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Return the object mapper.
- getObjectType() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- getOffset() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getOffsetAndMetadataProvider() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the offset and metadata provider.
- getOffsetHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the offset.
- getOneRecord(String, String, String, int, boolean, boolean, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Get a single record for the group from the topic/partition.
- getOrder() - Method in class org.springframework.kafka.annotation.KafkaListenerAnnotationBeanPostProcessor
- getOrder() - Method in interface org.springframework.kafka.config.StreamsBuilderFactoryBeanConfigurer
- getOriginal() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames
-
The header names for the original record headers.
- getParser() - Method in class org.springframework.kafka.support.serializer.ParseStringDeserializer
-
Get the configured parser function.
- getPartition() - Method in class org.springframework.kafka.event.ConsumerPartitionResumedEvent
- getPartition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getPartitionHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the partition.
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerPartitionPausedEvent
-
Return the paused partition.
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerPausedEvent
-
Return the paused partitions.
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerResumedEvent
- getPartitions() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
- getPartitionsPerTopic() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getPhase() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- getPhase() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- getPhase() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getPhase() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
- getPhase() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
- getPhysicalCloseTimeout() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Get the physical close timeout.
- getPhysicalCloseTimeout() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Get the physical close timeout.
- getPollTimeout() - Method in class org.springframework.kafka.listener.ConsumerProperties
- getPort() - Method in class org.springframework.kafka.test.core.BrokerAddress
- getPort() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- getPosition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getPostProcessors() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Get the current list of post processors.
- getPostProcessors() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getPostProcessors() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getPostProcessors() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Get the current list of post processors.
- getProducer() - Method in class org.springframework.kafka.core.KafkaResourceHolder
- getProducerConfigs() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return the configuration of a producer.
- getProducerFactory() - Method in interface org.springframework.kafka.core.KafkaOperations
-
Return the producer factory used by this template.
- getProducerFactory() - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the producer factory used by this template.
- getProducerFactory() - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- getProducerFactory() - Method in class org.springframework.kafka.transaction.ChainedKafkaTransactionManager
-
Deprecated.
- getProducerFactory() - Method in interface org.springframework.kafka.transaction.KafkaAwareTransactionManager
-
Get the producer factory.
- getProducerFactory() - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
-
Get the producer factory.
- getProducerFactory(String) - Method in class org.springframework.kafka.core.KafkaTemplate
-
Return the producer factory used by this template based on the topic.
- getProducerFactory(String) - Method in class org.springframework.kafka.core.RoutingKafkaTemplate
- getProducerRecord() - Method in class org.springframework.kafka.support.SendResult
- getPropertyValue(Object, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Uses nested
DirectFieldAccessor
s to obtain a property using dotted notation to traverse fields; e.g. - getPropertyValue(Object, String, Class<T>) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
A typed version of
KafkaTestUtils.getPropertyValue(Object, String)
. - getRawHeaders() - Method in class org.springframework.kafka.support.converter.KafkaMessageHeaders
- getReason() - Method in class org.springframework.kafka.event.ConsumerRetryAuthEvent
-
Return the reason for the auth failure.
- getReason() - Method in class org.springframework.kafka.event.ConsumerStoppedEvent
-
Return the reason why the consumer was stopped.
- getRecord() - Method in exception org.springframework.kafka.listener.BatchListenerFailedException
-
Return the failed record.
- getRecord() - Method in exception org.springframework.kafka.support.converter.ConversionException
-
Return the consumer record, if available.
- getRecordFilterStrategy() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getRecordFilterStrategy() - Method in class org.springframework.kafka.listener.adapter.AbstractFilteringMessageListener
- getRecordInterceptor() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
- getRecordMessageConverter() - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
-
Return the record converter used by this batch converter, if configured, or null.
- getRecordMessageConverter() - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- getRecordMetadata() - Method in class org.springframework.kafka.support.SendResult
- getRecords() - Method in exception org.springframework.kafka.support.converter.ConversionException
-
Return the consumer record, if available.
- getRecords(Consumer<K, V>) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer for records.
- getRecords(Consumer<K, V>, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer for records.
- getRecords(Consumer<K, V>, long, int) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer for records.
- getRecoveryCallback() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
- getRecoveryStrategy(List<ConsumerRecord<?, ?>>, Exception) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Deprecated.- no longer used.
- getRecoveryStrategy(List<ConsumerRecord<?, ?>>, Consumer<?, ?>, Exception) - Method in class org.springframework.kafka.listener.FailedRecordProcessor
-
Deprecated.- no longer used.
- getReplyHeadersConfigurer() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Return the reply configurer.
- getReplyTemplate() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getRequest() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- getResolver() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- getResult() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- getResult() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- getRetrySuffix() - Method in class org.springframework.kafka.retrytopic.DestinationTopicPropertiesFactory.DestinationTopicSuffixes
- getRetryTemplate() - Method in class org.springframework.kafka.listener.adapter.AbstractRetryingMessageListenerAdapter
- getScheduler() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return the task scheduler, if present.
- getScheduler() - Method in class org.springframework.kafka.retrytopic.RetryTopicSchedulerWrapper
- getSeekCallbackFor(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
Return the callback for the specified topic/partition.
- getSeekCallbacks() - Method in class org.springframework.kafka.listener.AbstractConsumerSeekAware
-
The map of callbacks for all currently assigned partitions.
- getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyFuture
- getSendFuture() - Method in class org.springframework.kafka.requestreply.RequestReplyMessageFuture
-
Return the send future.
- getSendTo() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- getShutdownTimeout() - Method in class org.springframework.kafka.listener.ContainerProperties
- getSingleRecord(Consumer<K, V>, String) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer, expecting a single record for the specified topic.
- getSingleRecord(Consumer<K, V>, String, long) - Static method in class org.springframework.kafka.test.utils.KafkaTestUtils
-
Poll the consumer, expecting a single record for the specified topic.
- getSnapshotDir() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker.EmbeddedZookeeper
- getSource() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
- getSource(Class<T>) - Method in class org.springframework.kafka.event.KafkaEvent
-
Get the container (source) that published the event.
- getSourceDestination() - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver.DestinationTopicHolder
- getStreamsConfiguration() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
- getStreamsUncaughtExceptionHandler() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Retrieves the current
StreamsUncaughtExceptionHandler
set on this factory bean. - getSubBatchPerPartition() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Return whether to split batches by partition; null if not set.
- getSyncCommitTimeout() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the sync commit timeout.
- getTheProducer(String) - Method in class org.springframework.kafka.core.KafkaTemplate
- getThingProp() - Method in class org.springframework.kafka.jdocs.requestreply.Application.Thing
- getTimeoutBuffer() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
-
The number of milliseconds to add to the producer configuration
delivery.timeout.ms
property to avoid timing out before the Kafka producer. - getTimeSinceLastPoll() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
How long since the last poll.
- getTimestamp() - Method in exception org.springframework.kafka.listener.TimestampedException
- getTimestampHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the timestamp.
- getTimestampTypeHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the timestamp type.
- getTopic() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- getTopic() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getTopicHeader() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.Original
-
The header name for the topic.
- getTopicName(String) - Method in interface org.springframework.kafka.retrytopic.RetryTopicNamesProviderFactory.RetryTopicNamesProvider
-
Return the tropic name that will override the base topic name.
- getTopicName(String) - Method in class org.springframework.kafka.retrytopic.SuffixingRetryTopicNamesProviderFactory.SuffixingRetryTopicNamesProvider
- getTopicPartition() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
-
The idle TopicPartition.
- getTopicPartition() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
-
The idle TopicPartition.
- getTopicPartition() - Method in exception org.springframework.kafka.listener.KafkaBackoffException
- getTopicPartition() - Method in class org.springframework.kafka.listener.KafkaConsumerBackoffManager.Context
- getTopicPartition() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
-
The TopicPartitions the container is listening to.
- getTopicPartitions() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
-
The TopicPartitions the container is listening to.
- getTopicPartitions() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
-
The TopicPartitions the container is listening to.
- getTopicPartitions() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the configured
TopicPartitionOffset
s. - getTopicPartitionsToAssign() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the topicPartitions for this endpoint.
- getTopicPartitionsToAssign() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the topicPartitions for this endpoint.
- getTopicPattern() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the topicPattern for this endpoint.
- getTopicPattern() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the topicPattern for this endpoint.
- getTopicPattern() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the configured topic pattern.
- getTopics() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
-
Return the topics for this endpoint.
- getTopics() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
-
Return the topics for this endpoint.
- getTopics() - Method in class org.springframework.kafka.listener.ConsumerProperties
-
Return the configured topics.
- getTopics() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getTopology() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
-
Providing access to the associated
Topology
of thisStreamsBuilderFactoryBean
. - getToStringClasses() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Provide direct access to the toString() classes by subclasses.
- getTransactionalResourceHolder(ProducerFactory<K, V>) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
-
Obtain a Producer that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder(ProducerFactory<K, V>, String, Duration) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
-
Obtain a Producer that is synchronized with the current transaction, if any.
- getTransactionalResourceHolder(ProducerFactory<K, V>, Duration) - Static method in class org.springframework.kafka.core.ProducerFactoryUtils
-
Obtain a Producer that is synchronized with the current transaction, if any.
- getTransactionDefinition() - Method in class org.springframework.kafka.listener.ContainerProperties
-
Get the transaction definition.
- getTransactionIdPrefix() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getTransactionIdPrefix() - Method in class org.springframework.kafka.core.KafkaTemplate
- getTransactionIdPrefix() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the transaction id prefix.
- getTransactionIdSuffix() - Static method in class org.springframework.kafka.support.TransactionSupport
-
Deprecated.
- getTransactionManager() - Method in class org.springframework.kafka.listener.ContainerProperties
- getTrustedPackages() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
-
Provide direct access to the trusted packages set for subclasses.
- getTxProducerConfigs(String) - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
-
Return the configuration of a transactional producer.
- getType() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
-
Returns the inferred type for conversion or, if null, the
fallbackType
. - getTypeMapper() - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
- getTypeMapper() - Method in class org.springframework.kafka.support.converter.MappingJacksonParameterizedConverter
-
Return the type mapper.
- getTypeMapper() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
- getTypeMapper() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
- getTypePrecedence() - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
-
Return the precedence.
- getTypePrecedence() - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- getUnregisteredListenerContainer(String) - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
- getUnregisteredListenerContainer(String) - Method in interface org.springframework.kafka.listener.ListenerContainerRegistry
-
Return the
MessageListenerContainer
with the specified id ornull
if no such container exists. - getUntrustedType() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- getValidator() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistrar
-
Get the validator, if supplied.
- getValue() - Method in class org.springframework.kafka.streams.HeaderEnricher.Container
- getValueDeserializer() - Method in interface org.springframework.kafka.core.ConsumerFactory
-
Return the configured value deserializer (if provided as an object instead of a class name in the properties).
- getValueDeserializer() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
- getValueSerializer() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getValueSerializer() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return the configured value serializer (if provided as an object instead of a class name in the properties).
- getValueSerializerSupplier() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- getValueSerializerSupplier() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return a supplier for a value serializer.
- getZkPort() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Get the port that the embedded Zookeeper is running on or will run on.
- getZookeeper() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- getZooKeeperClient() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
-
Return the ZooKeeperClient.
- getZookeeperConnectionString() - Method in class org.springframework.kafka.test.EmbeddedKafkaBroker
- GlobalEmbeddedKafkaTestExecutionListener - Class in org.springframework.kafka.test.junit
-
The
TestExecutionListener
to start anEmbeddedKafkaBroker
in the beginning of the test plan and stop in the end. - GlobalEmbeddedKafkaTestExecutionListener() - Constructor for class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
- GROUP - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The consumer group that received the failed record.
- GROUP_ID - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
For inbound messages, the container's
group.id
consumer property. - groupId() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
-
Override the
group.id
property for the consumer factory with this value for this listener only.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
CommonErrorHandler
.