Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
T
- targetType - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- TEMPLATE_OBSERVATION - Enum constant in enum class org.springframework.kafka.support.micrometer.KafkaTemplateObservation
-
Observation for KafkaTemplates.
- testPlanExecutionFinished(TestPlan) - Method in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
- testPlanExecutionStarted(TestPlan) - Method in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
- ThreadStateProcessor - Interface in org.springframework.kafka.listener
-
A general interface for managing thread-bound resources when a
Consumer
is available. - TIME - Enum constant in enum class org.springframework.kafka.listener.ContainerProperties.AckMode
-
Commit pending offsets after
ackTime
has elapsed. - timeout() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
-
The amount of time in milliseconds after which message retrying should give up and send the message to the DLT.
- timeoutAfter(long) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure a global timeout, in milliseconds, after which a record will go straight to the DLT the next time a listener throws an exception.
- timestamp() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- timestamp(long) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- timestamp(TimestampType, long) - Static method in class org.springframework.kafka.test.assertj.KafkaConditions
- TIMESTAMP - Enum constant in enum class org.springframework.kafka.support.TopicPartitionOffset.SeekPosition
-
Seek to the time stamp; if no records exist with a timestamp greater than or equal to the timestamp seek to the end.
- TIMESTAMP - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for holding the timestamp of the producer record.
- TIMESTAMP_TYPE - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header for holding the
type
of timestamp. - TimestampedException - Exception in org.springframework.kafka.listener
-
A
KafkaException
that records the timestamp of when it was thrown. - TimestampedException(Exception) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Constructs an instance with the provided cause and the current time.
- TimestampedException(Exception, long) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Creates an instance with the timestamp of when it was thrown and its cause.
- TimestampedException(Exception, Instant) - Constructor for exception org.springframework.kafka.listener.TimestampedException
-
Creates an instance with the Instant of when it was thrown and its cause.
- timestampHeader(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 timestamp of the original record.
- timestampType() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- timestampTypeHeader(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 timestampType of the original record.
- toClass(Headers) - Method in interface org.springframework.kafka.support.mapping.ClassMapper
- toClass(Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- ToFromStringSerde<T> - Class in org.springframework.kafka.support.serializer
-
A Serde that delegates to a
ToStringSerializer
andParseStringDeserializer
. - ToFromStringSerde(ToStringSerializer<T>, ParseStringDeserializer<T>) - Constructor for class org.springframework.kafka.support.serializer.ToFromStringSerde
-
Construct an instance with the provided properties.
- toHeaders(Headers, Map<String, Object>) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
- toHeaders(Headers, Map<String, Object>) - Method in interface org.springframework.kafka.support.KafkaHeaderMapper
-
Map from the given native headers to a map of headers for the eventual
MessageHeaders
. - toHeaders(Headers, Map<String, Object>) - Method in class org.springframework.kafka.support.SimpleKafkaHeaderMapper
- toJavaType(Headers) - Method in class org.springframework.kafka.support.mapping.DefaultJackson2JavaTypeMapper
- toJavaType(Headers) - Method in interface org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper
- toMessage(List<ConsumerRecord<?, ?>>, Acknowledgment, Consumer<?, ?>, Type) - Method in interface org.springframework.kafka.support.converter.BatchMessageConverter
-
Convert a list of
ConsumerRecord
to aMessage
. - toMessage(List<ConsumerRecord<?, ?>>, Acknowledgment, Consumer<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.BatchMessagingMessageConverter
- toMessage(ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Type) - Method in class org.springframework.kafka.support.converter.MessagingMessageConverter
- toMessage(ConsumerRecord<?, ?>, Acknowledgment, Consumer<?, ?>, Type) - Method in interface org.springframework.kafka.support.converter.RecordMessageConverter
-
Convert a
ConsumerRecord
to aMessage
. - toMessagingMessage(List, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.BatchMessagingMessageListenerAdapter
- toMessagingMessage(ConsumerRecord<K, V>, Acknowledgment, Consumer<?, ?>) - Method in class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter
- topic() - Element in annotation interface org.springframework.kafka.annotation.TopicPartition
-
The topic to listen on.
- topic() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- TOPIC - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The original topic of the failed record.
- TOPIC - Static variable in class org.springframework.kafka.support.KafkaHeaders
-
The header containing the topic when sending data to Kafka.
- TopicBuilder - Class in org.springframework.kafka.config
-
Builder for a
NewTopic
. - TopicForRetryable - Class in org.springframework.kafka.support
-
Marker to indicate this
NewTopic
is for retryable topics; admin will ignore these if a regularNewTopic
exist. - TopicForRetryable(String, int, short) - Constructor for class org.springframework.kafka.support.TopicForRetryable
-
Create an instance with the provided properties.
- topicHeader(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 topic of the original record.
- TopicPartition - Annotation Interface in org.springframework.kafka.annotation
-
Used to add topic/partition information to a
KafkaListener
. - TopicPartitionOffset - Class in org.springframework.kafka.support
-
A configuration container to represent a topic name, partition number and, optionally, an offset for it.
- TopicPartitionOffset(String, int) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with no initial offset management.
- TopicPartitionOffset(String, int, Long) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided initial offset with
TopicPartitionOffset.isRelativeToCurrent()
false. - TopicPartitionOffset(String, int, Long, boolean) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided initial offset.
- TopicPartitionOffset(String, int, Long, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided
TopicPartitionOffset.SeekPosition
. - TopicPartitionOffset(String, int, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided
TopicPartitionOffset.SeekPosition
. - TopicPartitionOffset(TopicPartition, Long, TopicPartitionOffset.SeekPosition) - Constructor for class org.springframework.kafka.support.TopicPartitionOffset
-
Construct an instance with the provided
TopicPartitionOffset.SeekPosition
. - TopicPartitionOffset.SeekPosition - Enum Class in org.springframework.kafka.support
-
Enumeration for "special" seeks.
- topicPartitions() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
-
The topicPartitions for this listener when using manual topic/partition assignment.
- topicPattern() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
-
The topic pattern for this listener.
- topics() - Element in annotation interface org.springframework.kafka.annotation.KafkaListener
-
The topics for this listener.
- topics() - Element in annotation interface org.springframework.kafka.test.context.EmbeddedKafka
-
Topics that should be created Topics may contain property place holders, e.g.
- TOPICS_PROPERTY_NAME - Static variable in class org.springframework.kafka.test.junit.GlobalEmbeddedKafkaTestExecutionListener
-
The topics to create on the embedded broker(s).
- topicSuffixingStrategy() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
-
Whether the retry topics will be suffixed with the delay value for that topic or a simple index.
- TopicSuffixingStrategy - Enum Class in org.springframework.kafka.retrytopic
-
Constants for the RetryTopic functionality.
- toString() - Method in class org.springframework.kafka.config.AbstractKafkaListenerEndpoint
- toString() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory.CloseSafeProducer
- toString() - Method in class org.springframework.kafka.event.ConsumerFailedToStartEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerPartitionPausedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerPartitionResumedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerPausedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerResumedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerRetryAuthEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerRetryAuthSuccessfulEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStartedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStartingEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStoppedEvent
- toString() - Method in class org.springframework.kafka.event.ConsumerStoppingEvent
- toString() - Method in class org.springframework.kafka.event.ContainerStoppedEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerIdleEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerNoLongerIdleEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerPartitionIdleEvent
- toString() - Method in class org.springframework.kafka.event.ListenerContainerPartitionNoLongerIdleEvent
- toString() - Method in class org.springframework.kafka.event.NonResponsiveConsumerEvent
- toString() - Method in class org.springframework.kafka.listener.adapter.ConsumerRecordMetadata
- toString() - Method in class org.springframework.kafka.listener.adapter.InvocationResult
- toString() - Method in record class org.springframework.kafka.listener.adapter.MessagingMessageListenerAdapter.ReplyExpressionRoot
-
Returns a string representation of this record class.
- toString() - Method in class org.springframework.kafka.listener.ConcurrentMessageListenerContainer
- toString() - Method in class org.springframework.kafka.listener.ConsumerProperties
- toString() - Method in class org.springframework.kafka.listener.ContainerGroup
- toString() - Method in class org.springframework.kafka.listener.ContainerProperties
- toString() - Method in class org.springframework.kafka.listener.KafkaMessageListenerContainer
- toString() - Method in class org.springframework.kafka.requestreply.CorrelationKey
- toString() - Method in class org.springframework.kafka.retrytopic.DestinationTopic.Properties
- toString() - Method in class org.springframework.kafka.retrytopic.DestinationTopic
- toString() - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper.NonTrustedHeaderType
- toString() - Method in class org.springframework.kafka.support.SendResult
- toString() - Method in class org.springframework.kafka.support.serializer.FailedDeserializationInfo
- toString() - Method in class org.springframework.kafka.support.TopicPartitionOffset
- toString() - Method in class org.springframework.kafka.test.core.BrokerAddress
- ToStringSerializer<T> - Class in org.springframework.kafka.support.serializer
-
Generic
Serializer
that relies onObject.toString()
to get serialized representation of the entity. - ToStringSerializer() - Constructor for class org.springframework.kafka.support.serializer.ToStringSerializer
- TRACE - Enum constant in enum class org.springframework.kafka.KafkaException.Level
-
Trace.
- TRACE - Enum constant in enum class org.springframework.kafka.support.LogIfLevelEnabled.Level
-
Trace.
- transactionCapable() - Method in class org.springframework.kafka.core.DefaultKafkaProducerFactory
- transactionCapable() - Method in interface org.springframework.kafka.core.ProducerFactory
-
Return true if the factory supports transactions.
- transactionCapable() - Method in class org.springframework.kafka.mock.MockProducerFactory
- transactionManager() - Method in class org.springframework.kafka.core.reactive.ReactiveKafkaProducerTemplate
- transform(K, V) - Method in class org.springframework.kafka.streams.HeaderEnricher
-
Deprecated.
- transform(K, V) - Method in class org.springframework.kafka.streams.messaging.MessagingTransformer
-
Deprecated.
- traversingCauses() - Element in annotation interface org.springframework.kafka.annotation.RetryableTopic
-
Whether or not the captured exception should be traversed to look for the exceptions provided above.
- traversingCauses() - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure the classifier to traverse the cause chain.
- traversingCauses(boolean) - Method in class org.springframework.kafka.retrytopic.RetryTopicConfigurationBuilder
-
Configure the classifier to traverse, or not, the cause chain.
- trusted(String) - Method in class org.springframework.kafka.support.DefaultKafkaHeaderMapper
- TRUSTED_PACKAGES - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property for trusted deserialization packages.
- trustedPackages(String...) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Add trusted packages to the default type mapper.
- TS - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The timestamp of the failed record.
- TS_TYPE - Enum constant in enum class org.springframework.kafka.listener.DeadLetterPublishingRecoverer.HeaderNames.HeadersToAdd
-
The timestamp type of the failed record.
- TYPE_ID - Enum constant in enum class org.springframework.kafka.support.mapping.Jackson2JavaTypeMapper.TypePrecedence
-
The type is obtained from headers.
- TYPE_MAPPINGS - Static variable in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Kafka config property to add type mappings to the type mapper: 'foo=com.Foo,bar=com.Bar'.
- TYPE_MAPPINGS - Static variable in class org.springframework.kafka.support.serializer.JsonSerializer
-
Kafka config property to add type mappings to the type mapper: 'foo:com.Foo,bar:com.Bar'.
- typeFunction(BiFunction<byte[], Headers, JavaType>) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
BiFunction
that receives the data to be deserialized and the headers and returns a JavaType. - typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonDeserializer
- typeMapper - Variable in class org.springframework.kafka.support.serializer.JsonSerializer
- typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Use the supplied
Jackson2JavaTypeMapper
. - typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerde
-
Use the supplied
Jackson2JavaTypeMapper
. - typeMapper(Jackson2JavaTypeMapper) - Method in class org.springframework.kafka.support.serializer.JsonSerializer
-
Use the supplied
Jackson2JavaTypeMapper
. - typeResolver(JsonTypeResolver) - Method in class org.springframework.kafka.support.serializer.JsonDeserializer
-
Set a
JsonTypeResolver
that receives the data to be deserialized and the headers and returns a JavaType.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form