Index

A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

I

id() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
The unique identifier of the container for this listener.
idIsGroup() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
When groupId is not provided, use the id (if provided) as the group.id property for the consumer.
ignoreTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
Ignore type information headers and use the configured target class.
ignoreTypeHeaders() - Method in class org.springframework.kafka.support.serializer.JsonSerde
Ignore type information headers and use the configured target class.
include() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
The exception types that should be retried.
includeHeader(DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd...) - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
Set the header inclusion bit for the header name.
includeNames() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
The exception class names that should be retried.
includeTopic(String) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
Configure a topic name for which to use the target configuration.
includeTopics(List<String>) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
Configure the topic names for which to use the target configuration.
INFERRED - Enum constant in enum class org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
The type is inferred from the destination method.
info() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
Static information that will be added as a header with key KafkaHeaders.LISTENER_INFO.
INFO - Enum constant in enum class org.springframework.kafka.KafkaException.Level
Info.
INFO - Enum constant in enum class org.springframework.kafka.support.LogIfLevelEnabled.Level
Info.
initArgumentResolvers() - Method in class org.springframework.kafka.listener.adapter.KafkaMessageHandlerMethodFactory
 
initialize() - Method in class org.springframework.kafka.core.KafkaAdmin
Call this method to check/add topics; this might be needed if the broker was not available when the application context was initialized, and fatalIfBrokerNotAvailable is false, or autoCreate was set to false.
initialize() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
 
initializeContainer(C, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Further initialize the specified container.
initializeContainer(ConcurrentMessageListenerContainer<K, V>, KafkaListenerEndpoint) - Method in class org.springframework.kafka.config.ConcurrentKafkaListenerContainerFactory
 
initialOffset() - Element in annotation interface org.springframework.kafka.annotation.PartitionOffset
The initial offset of the PartitionOffset.partition().
initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.JsonMessageConverter
 
initialRecordHeaders(Message<?>) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
Subclasses can populate additional headers before they are mapped.
initTransactions() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
 
INSTANCE - Static variable in class org.springframework.kafka.support.JavaUtils
The singleton instance of this utility class.
INSTANCE - Static variable in class org.springframework.kafka.support.KafkaNull
Instance of KafkaNull.
INSTANCE - Static variable in class org.springframework.kafka.support.micrometer.KafkaListenerObservation.DefaultKafkaListenerObservationConvention
A singleton instance of the convention.
INSTANCE - Static variable in class org.springframework.kafka.support.micrometer.KafkaTemplateObservation.DefaultKafkaTemplateObservationConvention
A singleton instance of the convention.
instantiateAndConfigure(Map<String, ?>, boolean, Map<String, Deserializer<?>>, String, Class<?>) - Static method in class org.springframework.kafka.support.serializer.DelegatingDeserializer
 
instantiateAndConfigure(Map<String, ?>, boolean, Map<String, Serializer<?>>, String, Class<?>) - Static method in class org.springframework.kafka.support.serializer.DelegatingSerializer
 
instantiateAndConfigure(Map<String, ?>, boolean, Map<Pattern, T>, Pattern, Class<?>) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
 
intercept(ConsumerRecord<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeRecordInterceptor
 
intercept(ConsumerRecord<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.RecordInterceptor
Perform some action on the record or return a different one.
intercept(ConsumerRecords<K, V>, Consumer<K, V>) - Method in interface org.springframework.kafka.listener.BatchInterceptor
Perform some action on the records or return a different one.
intercept(ConsumerRecords<K, V>, Consumer<K, V>) - Method in class org.springframework.kafka.listener.CompositeBatchInterceptor
 
internalRetryTopicClock() - Method in class org.springframework.kafka.retrytopic.RetryTopicComponentFactory
Return the Clock instance that will be used for all time-related operations in the retry topic processes.
inTransaction() - Method in interface org.springframework.kafka.core.KafkaOperations
Return true if the template is currently running in a transaction on the calling thread.
inTransaction() - Method in class org.springframework.kafka.core.KafkaTemplate
Return true if the template is currently running in a transaction on the calling thread.
InvocationResult - Record Class in org.springframework.kafka.listener.adapter
The result of a method invocation.
InvocationResult(Object, Expression, boolean) - Constructor for record class org.springframework.kafka.listener.adapter.InvocationResult
Creates an instance of a InvocationResult record class.
invoke(Object, Acknowledgment, Consumer<?, ?>, Message<?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
invoke(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>, Message<?>) - Method in interface org.springframework.kafka.listener.adapter.BatchToRecordAdapter.Callback
Handle each message.
invoke(Message<?>, Object...) - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Invoke the method with the given message.
invoke(Message<?>, Object...) - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
 
invokeHandler(Object, Acknowledgment, Message<?>, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
Invoke the handler, wrapping any exception to a ListenerExecutionFailedException with a dedicated error message.
isAckAfterHandle() - Method in class org.springframework.kafka.listener.CommonDelegatingErrorHandler
 
isAckAfterHandle() - Method in interface org.springframework.kafka.listener.CommonErrorHandler
Return true if the offset should be committed for a handled error (no exception thrown).
isAckAfterHandle() - Method in class org.springframework.kafka.listener.CommonLoggingErrorHandler
 
isAckAfterHandle() - Method in class org.springframework.kafka.listener.CommonMixedErrorHandler
 
isAckAfterHandle() - Method in class org.springframework.kafka.listener.DefaultErrorHandler
 
isAckDiscarded() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.JsonSerializer
 
isAddTypeInfo() - Method in class org.springframework.kafka.support.serializer.ToStringSerializer
Get the addTypeInfo property.
isAllowed(T) - Method in class org.springframework.kafka.support.AllowDenyCollectionManager
 
isAllowNonTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations
Return true if this template, when transactional, allows non-transactional operations.
isAllowNonTransactional() - Method in class org.springframework.kafka.core.KafkaTemplate
 
isAlwaysRetryOnDltFailure() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
 
isAssignable() - Method in class org.springframework.kafka.support.serializer.DelegatingByTypeSerializer
Returns true if DelegatingByTypeSerializer.findDelegate(Object, Map) should consider assignability to the key rather than an exact match.
isAsyncAcks() - Method in class org.springframework.kafka.listener.ContainerProperties
When true, async manual acknowledgments are supported.
isAsyncReplies() - Method in interface org.springframework.kafka.listener.adapter.AsyncRepliesAware
Return true if the HandlerAdapter return type is async.
isAsyncReplies() - Method in class org.springframework.kafka.listener.adapter.DelegatingInvocableHandler
Return true if any handler method has an async reply type.
isAsyncReplies() - Method in class org.springframework.kafka.listener.adapter.HandlerAdapter
Return true if any handler method has an async reply type.
isAsyncReplies() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isAsyncReply(Class<?>) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
Return the true when return types are asynchronous.
isAutoCommit() - Method in interface org.springframework.kafka.core.ConsumerFactory
Return true if consumers created by this factory use auto commit.
isAutoCommit() - Method in class org.springframework.kafka.core.DefaultKafkaConsumerFactory
 
isAutoCommit() - Method in class org.springframework.kafka.mock.MockConsumerFactory
 
isAutoStartup() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
isAutoStartup() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isAutoStartup() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
 
isAutoStartup() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
isBackoffException(Exception) - Static method in class org.springframework.kafka.listener.SeekUtils
Return true if the exception is a KafkaBackoffException.
isBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerContainerFactory
Return true if this endpoint creates a batch listener.
isBatchListener() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
Return true if this endpoint creates a batch listener.
isBatchRecoverAfterRollback() - Method in class org.springframework.kafka.listener.ContainerProperties
Recover batch records after rollback if true.
isBinaryCorrelation() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
isChangeConsumerThreadName() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Return true if the container should change the consumer thread name during initialization.
isCheckDeserExWhenKeyNull() - Method in class org.springframework.kafka.listener.ConsumerProperties
Always check for a deserialization exception header with a null key.
isCheckDeserExWhenValueNull() - Method in class org.springframework.kafka.listener.ConsumerProperties
Always check for a deserialization exception header with a null value.
isChildRunning() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
isChildRunning() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
If this container has child containers, return true if at least one child is running.
isCommitRecovered() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Whether the offset for a recovered record should be committed.
isCompletableFuture(Class<?>) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
Return the true when type is CompletableFuture.
isConfigureSerializers() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
If true (default), programmatically provided serializers (via constructor or setters) will be configured using the producer configuration.
isConsumerRecordList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isConsumerRecords() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isContainerPaused() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
isContainerPaused() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
isContainerPaused() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return true if MessageListenerContainer.pause() has been called; and all consumers in this container have actually paused.
isContextRefreshed() - Method in class org.springframework.kafka.retrytopic.DefaultDestinationTopicResolver
Return true if the application context is refreshed.
isConversionNeeded() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isDefault() - Element in annotation interface org.springframework.kafka.annotation.KafkaHandler
When true, designate that this is the default fallback method if the payload type matches no other KafkaHandler method.
isDeliveryAttemptHeader() - Method in class org.springframework.kafka.listener.ContainerProperties
 
isDltTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
 
isDltTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
 
isEmptyPayload(Object) - Method in class org.springframework.kafka.listener.adapter.KafkaNullAwarePayloadArgumentResolver
 
isEncodeStrings() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
 
isExistingTransaction(Object) - Method in class org.springframework.kafka.transaction.KafkaTransactionManager
 
isFailIfSendResultIsError() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
If true, wait for the send result and throw an exception if it fails.
isFixTxOffsets() - Method in class org.springframework.kafka.listener.ConsumerProperties
Whether or not to correct terminal transactional offsets.
isForKey() - Method in class org.springframework.kafka.support.serializer.ErrorHandlingDeserializer
 
isForKey() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
 
isInExpectedState() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
isInExpectedState() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
isInExpectedState() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return true if the container is running, has never been started, or has been stopped.
isInstance(Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicDeserializer
 
isInstance(Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerialization
Return true if this object is an instance of T.
isInstance(Object) - Method in class org.springframework.kafka.support.serializer.DelegatingByTopicSerializer
 
isInterceptBeforeTx() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isJackson2Present() - Static method in class org.springframework.kafka.support.JacksonPresent
 
isKey() - Method in exception org.springframework.kafka.support.serializer.DeserializationException
True if deserialization of the key failed, otherwise deserialization of the value failed.
isLogContainerConfig() - Method in class org.springframework.kafka.listener.ContainerProperties
Log the container configuration if true (INFO).
isMainEndpoint() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
 
isMainTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
 
isMessageList() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
 
isMicrometerEnabled() - Method in class org.springframework.kafka.listener.ContainerProperties
 
isMissingTopicsFatal() - Method in class org.springframework.kafka.listener.ContainerProperties
If true, the container won't start if any of the configured topics are not present on the broker.
isMono(Class<?>) - Static method in class org.springframework.kafka.listener.adapter.AdapterUtils
Return the true when type is Mono.
isNegated() - Method in interface org.springframework.kafka.support.AbstractKafkaHeaderMapper.HeaderMatcher
Return true if this matcher is a negative matcher.
isNegated() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.NeverMatchHeaderMatcher
 
isNegated() - Method in class org.springframework.kafka.support.AbstractKafkaHeaderMapper.SimplePatternBasedHeaderMatcher
 
isNoOpsTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
 
isObservationEnabled() - Method in class org.springframework.kafka.listener.ContainerProperties
 
isOutOfOrderCommit() - Method in interface org.springframework.kafka.support.Acknowledgment
 
isPartitionPaused(TopicPartition) - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
 
isPartitionPaused(TopicPartition) - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
 
isPartitionPaused(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Whether or not this topic's partition is currently paused.
isPartitionPauseRequested(TopicPartition) - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isPartitionPauseRequested(TopicPartition) - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Whether or not this topic's partition pause has been requested.
isPaused() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
Return true if the consumer was paused at the time the idle event was published.
isPaused() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
Return true if the consumer was paused at the time the idle event was published.
isPaused() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
Deprecated, for removal: This API element is subject to removal in a future version.
isPauseImmediate() - Method in class org.springframework.kafka.listener.ContainerProperties
When pausing the container with a record listener, whether the pause takes effect immediately, when the current record has been processed, or after all records from the previous poll have been processed.
isPauseRequested() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isPauseRequested() - Method in interface org.springframework.kafka.listener.MessageListenerContainer
Return true if MessageListenerContainer.pause() has been called; the container might not have actually paused yet.
isPending(Object) - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
Return true if this correlation id is still active.
isPrimary() - Method in class org.springframework.kafka.core.ABSwitchCluster
Get whether or not the primary cluster is active.
isProcessInTransaction() - Method in interface org.springframework.kafka.listener.AfterRollbackProcessor
isProcessInTransaction() - Method in class org.springframework.kafka.listener.DefaultAfterRollbackProcessor
 
isProducerPerThread() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
isProducerPerThread() - Method in interface org.springframework.kafka.core.ProducerFactory
Return true when there is a producer per thread.
isRelativeToCurrent() - Method in class org.springframework.kafka.support.TopicPartitionOffset
 
isRestartAfterAuthExceptions() - Method in class org.springframework.kafka.listener.ContainerProperties
Restart the container if stopped due to an auth exception.
isRetryTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
 
isReusableRetryTopic() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
 
isRunning() - Method in class org.springframework.kafka.config.KafkaListenerEndpointRegistry
 
isRunning() - Method in class org.springframework.kafka.config.StreamsBuilderFactoryBean
 
isRunning() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
 
isRunning() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isRunning() - Method in class org.springframework.kafka.listener.ContainerGroup
 
isRunning() - Method in class org.springframework.kafka.listener.ContainerGroupSequencer
 
isRunning() - Method in class org.springframework.kafka.requestreply.ReplyingKafkaTemplate
 
isSeekAfterError() - Method in class org.springframework.kafka.listener.FailedRecordProcessor
Return whether to seek after an exception is handled.
isSplitIterables() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
 
isSplitIterables() - Method in interface org.springframework.kafka.config.KafkaListenerEndpoint
When true, Iterable return results will be split into discrete records.
isSplitIterables() - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
When true, Iterable return results will be split into discrete records.
isStopContainerWhenFenced() - Method in class org.springframework.kafka.listener.ContainerProperties
When true, the container will stop after a ProducerFencedException.
isStopImmediate() - Method in class org.springframework.kafka.listener.ContainerProperties
When true, the container will be stopped immediately after processing the current record.
isStoppedNormally() - Method in class org.springframework.kafka.listener.AbstractMessageListenerContainer
 
isSubBatchPerPartition() - Method in class org.springframework.kafka.listener.ContainerProperties
Return whether to split batches by partition.
isSyncCommits() - Method in class org.springframework.kafka.listener.ConsumerProperties
 
isTransactional() - Method in interface org.springframework.kafka.core.KafkaOperations
Return true if the implementation supports transactions (has a transaction-capable producer factory).
isTransactional() - Method in class org.springframework.kafka.core.KafkaTemplate
 
isTransactional() - Method in class org.springframework.kafka.listener.DeadLetterPublishingRecoverer
True if publishing should run in a transaction.
A B C D E F G H I J K L M N O P R S T U V W Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form