Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractKafkaChannel - Class in org.springframework.integration.kafka.channel
 - 
Abstract MessageChannel backed by an Apache Kafka topic.
 - AbstractKafkaChannel(KafkaOperations<?, ?>, String) - Constructor for class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 - 
Construct an instance with the provided
KafkaOperationsand topic. - AbstractKafkaChannelSpec<S extends AbstractKafkaChannelSpec<S,
C>, C extends AbstractKafkaChannel> - Class in org.springframework.integration.kafka.dsl  - 
Spec for a message channel backed by an Apache Kafka topic.
 - AbstractKafkaChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 - accept(ConsumerRecord<?, ?>, Exception) - Method in class org.springframework.integration.kafka.inbound.KafkaErrorSendingMessageRecoverer
 - ackCount(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the number of outstanding record count after which offsets should be committed when
ContainerProperties.AckMode.COUNTorContainerProperties.AckMode.COUNT_TIMEis being used. - ackDiscarded(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
A
booleanflag to indicate ifFilteringMessageListenerAdaptershould acknowledge discarded records or not. - ackMode(ContainerProperties.AckMode) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the ack mode to use when auto ack (in the configuration properties) is false.
 - acknowledge() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 - acknowledge(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 - ackTime(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the time (ms) after which outstanding offsets should be committed when
ContainerProperties.AckMode.TIMEorContainerProperties.AckMode.COUNT_TIMEis being used. - addInterceptor(int, ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - addInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - assigmentDuration(Duration) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec
 - 
Set the time to wait for partition assignment, when used as a gateway, to determine the default reply-to topic/partition.
 
B
- batch - Enum constant in enum class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
 - 
Each
Messagewill be converted from theConsumerRecordsreturned by a poll. - batchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
Set the message converter to use with a batch-based consumer.
 - beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - beforeShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - buildBeanDefinition(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaChannelParser
 - buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
 
C
- channel(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create a spec for a subscribable channel with the provided parameters.
 - commitCallback(OffsetCommitCallback) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
 - commonOutboundProperties(Element, ParserContext, BeanDefinitionBuilder) - Static method in class org.springframework.integration.kafka.config.xml.KafkaParsingUtils
 - compareTo(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - concurrency(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Specify a concurrency maximum number for the
AbstractMessageListenerContainer. - configureKafkaTemplate(Consumer<KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K, V, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
 - 
Configure a Kafka Template by invoking the
Consumercallback, with aKafkaTemplateSpecargument. - configureKafkaTemplate(Consumer<KafkaTemplateSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 - 
Configure a Kafka Template by invoking the
Consumercallback, with aKafkaTemplateSpecargument. - configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
 - 
Configure a listener container by invoking the
Consumercallback, with aKafkaMessageListenerContainerSpecargument. - configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
 - 
Configure a listener container by invoking the
Consumercallback, with aKafkaMessageListenerContainerSpecargument. - configureTemplate(Consumer<KafkaTemplateSpec<K, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
 - 
Configure a template by invoking the
Consumercallback, with aKafkaTemplateSpecargument. - consumerProperties() - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 - 
Returns the value of the
consumerPropertiesrecord component. - consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the user defined
ConsumerRebalanceListenerimplementation. - CONTEXT_ACKNOWLEDGMENT - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
 - 
RetryContextattribute key for an acknowledgment if the listener is capable of acknowledging. - CONTEXT_CONSUMER - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
 - 
RetryContextattribute key for the consumer if the listener is consumer-aware. - CONTEXT_RECORD - Static variable in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
 - 
RetryContextattribute key for the record. - create(Message<?>, String, Integer, Long, K, V, Headers) - Method in interface org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler.ProducerRecordCreator
 - 
Create a record.
 - createCallback(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 - createConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - createDispatcher() - Method in class org.springframework.integration.kafka.channel.PublishSubscribeKafkaChannel
 - createDispatcher() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 
D
- defaultReplyTimeout(Duration) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
 - 
Default reply timeout.
 - defaultTopic(String) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 - 
/** Set the default topic for send methods where a topic is not providing.
 - destroy() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - doInit() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - doParse(Element, ParserContext, String) - Method in class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
 - doPostProcess(BeanDefinitionBuilder, Element) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 - doReceive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - doReceive() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - doSend(Message<?>, long) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 - doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - doWithRetry(RetryTemplate, RecoveryCallback<?>, Object, Acknowledgment, Consumer<?, ?>, Runnable) - Method in interface org.springframework.integration.kafka.inbound.KafkaInboundEndpoint
 - 
Execute the runnable with the retry template and recovery callback.
 
E
- equals(Object) - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 - 
Indicates whether some other object is "equal to" this one.
 - errorHandler(CommonErrorHandler) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Specify an
CommonErrorHandlerfor theAbstractMessageListenerContainer. 
F
- filterInRetry(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
The
booleanflag to specify the order in which the filter and retry operations are performed. - flush(Function<Message<P>, Boolean>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a
Functionthat will be invoked at runtime to determine whether to flush the producer after send. - FLUSH - Static variable in class org.springframework.integration.kafka.support.KafkaIntegrationHeaders
 - 
Set to
Boolean.TRUEto flush after sending. - flushExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a SpEL expression to determine whether to flush the producer after a send.
 - flushExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure an
Expressionto determine whether to flush the producer after a send. - FUTURE_TOKEN - Static variable in class org.springframework.integration.kafka.support.KafkaIntegrationHeaders
 - 
Set to a token to correlate a send Future.
 - futuresChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set the channel to which send futures are sent.
 - futuresChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set the channel to which send futures are sent.
 
G
- getAssignedPartitions() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Return the currently assigned partitions.
 - getBeanClass(Element) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 - getClientId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getCommitTimeout() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 - getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
 - getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
 - getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec
 - getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 - getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getComponentType() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - getConsumer() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - getConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - getConsumerMonitor() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - getConsumerMonitor() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - getConsumerProperties() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Get a reference to the configured consumer properties; allows further customization of the properties before the source is started.
 - getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - getFuturesChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - getGroupId() - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 - getGroupId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getGroupId() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - getGroupId() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - getHeaderMapper() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - getInputChannelAttributeName() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 - getKafkaTemplate() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - getMessageConverter() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getOffsets() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - getOffsets() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - getPayloadType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getPhase() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - getPollTimeout() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getRebalanceListener() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - getRecord() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - getRecord() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - getRecord() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
 - getSendFailureChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - getSendSuccessChannel() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - getTemplate() - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 - getTopicPartition() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - getTopicPartition() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - groupId - Variable in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 - groupId(String) - Method in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 - 
Set the group id to use on the consumer side.
 - groupId(String) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the group id for this container.
 
H
- handleRequestMessage(Message<?>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - hasExecutorInterceptors() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - hashCode() - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 - 
Returns a hash code value for this object.
 - headerMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Specify a header mapper to map spring messaging headers to Kafka headers.
 
I
- id(String) - Method in class org.springframework.integration.kafka.dsl.AbstractKafkaChannelSpec
 - id(String) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - id(String) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 - idleEventInterval(Long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the idle event interval; when set, an event is emitted if a poll returns no records and this interval has elapsed since a record was returned.
 - inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundChannelAdapterSpecwith the consumer factory and topics. - inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, boolean) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundChannelAdapterSpecwith the consumer factory and topics. - inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundChannelAdapterSpecwith the consumer factory and topics with a custom ack callback factory. - inboundChannelAdapter(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, boolean) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundChannelAdapterSpecwith the consumer factory and topics with a custom ack callback factory. - inboundGateway(KafkaMessageListenerContainerSpec<K, V>, KafkaTemplateSpec<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundGatewaySpecwith the provided container and template specs. - inboundGateway(ConsumerFactory<K, V>, ContainerProperties, ProducerFactory<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundGatewaySpecwith the provided consumer factory, container properties and producer factory. - inboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaInboundGatewaySpecwith the provided container and template. - init() - Method in class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
 - isAckDeferred() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - isAckDeferred() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - isAcknowledged() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 - isAutoAck() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 - isAutoStartup() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - isEligibleAttribute(String) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 - isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - isPaused() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - isRawMessageHeader() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - isRolledBack() - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - isRolledBack() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - isRunning() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - isRunning() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - isRunning() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
K
- Kafka - Class in org.springframework.integration.kafka.dsl
 - 
Factory class for Apache Kafka components.
 - KafkaAckCallback(KafkaMessageSource.KafkaAckInfo<K, V>, ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 - 
Construct an instance with the provided properties.
 - KafkaAckCallbackFactory(ConsumerProperties) - Constructor for record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 - 
Creates an instance of a
KafkaAckCallbackFactoryrecord class. - KafkaChannelParser - Class in org.springframework.integration.kafka.config.xml
 - 
Parser for a channel backed by an Apache Kafka topic.
 - KafkaChannelParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaChannelParser
 - KafkaErrorSendingMessageRecoverer - Class in org.springframework.integration.kafka.inbound
 - 
An extension of
ErrorMessagePublisherthat can be used in aCommonErrorHandlerfor recovering Kafka delivery failures. - KafkaErrorSendingMessageRecoverer(MessageChannel) - Constructor for class org.springframework.integration.kafka.inbound.KafkaErrorSendingMessageRecoverer
 - 
Construct an instance to send to the channel with the
RawRecordHeaderErrorMessageStrategy. - KafkaErrorSendingMessageRecoverer(MessageChannel, ErrorMessageStrategy) - Constructor for class org.springframework.integration.kafka.inbound.KafkaErrorSendingMessageRecoverer
 - 
Construct an instance to send the channel, using the error message strategy.
 - KafkaInboundChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
 - 
Parser for the inbound channel adapter.
 - KafkaInboundChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 - KafkaInboundChannelAdapterSpec<K,
V> - Class in org.springframework.integration.kafka.dsl  - 
Spec for a polled Apache Kafka inbound channel adapter.
 - KafkaInboundEndpoint - Interface in org.springframework.integration.kafka.inbound
 - 
Implementations of this interface will generally support a retry template for retrying incoming deliveries and this supports adding common attributes to the retry context.
 - KafkaInboundGateway<K,
V, R> - Class in org.springframework.integration.kafka.inbound  - 
Inbound gateway.
 - KafkaInboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
Construct an instance with the provided container.
 - KafkaInboundGatewayParser - Class in org.springframework.integration.kafka.config.xml
 - 
Inbound gateway parser.
 - KafkaInboundGatewayParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 - KafkaInboundGatewaySpec<K,
V, R, S extends KafkaInboundGatewaySpec<K, V, R, S>> - Class in org.springframework.integration.kafka.dsl  - 
A
MessagingGatewaySpecimplementation for theKafkaInboundGateway. - KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec<K,
V, R> - Class in org.springframework.integration.kafka.dsl  - 
A
ConcurrentMessageListenerContainerconfigurationKafkaInboundGatewaySpecextension. - KafkaIntegrationHeaders - Class in org.springframework.integration.kafka.support
 - 
Headers specifically for Spring Integration components.
 - KafkaMessageDrivenChannelAdapter<K,
V> - Class in org.springframework.integration.kafka.inbound  - 
Message-driven channel adapter.
 - KafkaMessageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Construct an instance with mode
KafkaMessageDrivenChannelAdapter.ListenerMode.record. - KafkaMessageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Construct an instance with the provided mode.
 - KafkaMessageDrivenChannelAdapter.ListenerMode - Enum Class in org.springframework.integration.kafka.inbound
 - 
The listener mode for the container, record or batch.
 - KafkaMessageDrivenChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
 - 
Parser for the message driven channel adapter.
 - KafkaMessageDrivenChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
 - KafkaMessageDrivenChannelAdapterSpec<K,
V, S extends KafkaMessageDrivenChannelAdapterSpec<K, V, S>> - Class in org.springframework.integration.kafka.dsl  - 
A
MessageProducerSpecimplementation for theKafkaMessageDrivenChannelAdapter. - KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec<K,
V> - Class in org.springframework.integration.kafka.dsl  - 
A
ConcurrentMessageListenerContainerconfigurationKafkaMessageDrivenChannelAdapterSpecextension. - KafkaMessageListenerContainerSpec<K,
V> - Class in org.springframework.integration.kafka.dsl  - 
A helper class in the Builder pattern style to delegate options to the
ConcurrentMessageListenerContainer. - KafkaMessageSource<K,
V> - Class in org.springframework.integration.kafka.inbound  - 
Polled message source for Apache Kafka.
 - KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Construct an instance with the supplied parameters.
 - KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, boolean) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Construct an instance with the supplied parameters.
 - KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Construct an instance with the supplied parameters.
 - KafkaMessageSource(ConsumerFactory<K, V>, ConsumerProperties, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, boolean) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Construct an instance with the supplied parameters.
 - KafkaMessageSource.KafkaAckCallback<K,
V> - Class in org.springframework.integration.kafka.inbound  - 
AcknowledgmentCallback for Kafka.
 - KafkaMessageSource.KafkaAckCallbackFactory<K,
V> - Record Class in org.springframework.integration.kafka.inbound  - 
AcknowledgmentCallbackFactory for KafkaAckInfo.
 - KafkaMessageSource.KafkaAckInfo<K,
V> - Interface in org.springframework.integration.kafka.inbound  - 
Information for building an KafkaAckCallback.
 - KafkaMessageSource.KafkaAckInfoImpl - Class in org.springframework.integration.kafka.inbound
 - 
Information for building an KafkaAckCallback.
 - KafkaNamespaceHandler - Class in org.springframework.integration.kafka.config.xml
 - 
The namespace handler for the Apache Kafka namespace.
 - KafkaNamespaceHandler() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
 - KafkaOutboundChannelAdapterParser - Class in org.springframework.integration.kafka.config.xml
 - 
Parser for the outbound channel adapter.
 - KafkaOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaOutboundChannelAdapterParser
 - KafkaOutboundGatewayParser - Class in org.springframework.integration.kafka.config.xml
 - 
Parser for the outbound gateway.
 - KafkaOutboundGatewayParser() - Constructor for class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 - KafkaOutboundGatewaySpec<K,
V, R, S extends KafkaOutboundGatewaySpec<K, V, R, S>> - Class in org.springframework.integration.kafka.dsl  - 
A
MessageHandlerSpecimplementation for theKafkaProducerMessageHandleras a gateway. - KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec<K,
V, R> - Class in org.springframework.integration.kafka.dsl  - 
A
KafkaTemplate-basedKafkaProducerMessageHandlerSpecextension. - KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K,
V, R> - Class in org.springframework.integration.kafka.dsl  - 
An
IntegrationComponentSpecimplementation for theKafkaTemplate. - KafkaParsingUtils - Class in org.springframework.integration.kafka.config.xml
 - 
Utilities to assist with parsing XML.
 - KafkaPointToPointChannelSpec - Class in org.springframework.integration.kafka.dsl
 - 
Spec for a point to point channel backed by an Apache Kafka topic.
 - KafkaPointToPointChannelSpec(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPointToPointChannelSpec
 - KafkaPollableChannelSpec - Class in org.springframework.integration.kafka.dsl
 - 
Spec for a pollable channel.
 - KafkaPollableChannelSpec(KafkaTemplate<?, ?>, KafkaMessageSource<?, ?>) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPollableChannelSpec
 - KafkaProducerMessageHandler<K,
V> - Class in org.springframework.integration.kafka.outbound  - 
A Message Handler for Apache Kafka; when supplied with a
ReplyingKafkaTemplateit is used as the handler in an outbound gateway. - KafkaProducerMessageHandler(KafkaTemplate<K, V>) - Constructor for class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - KafkaProducerMessageHandler.ProducerRecordCreator<K,
V> - Interface in org.springframework.integration.kafka.outbound  - 
Creates a
ProducerRecordfrom aMessageand/or properties derived from configuration and/or the message. - KafkaProducerMessageHandlerSpec<K,
V, S extends KafkaProducerMessageHandlerSpec<K, V, S>> - Class in org.springframework.integration.kafka.dsl  - 
A
MessageHandlerSpecimplementation for theKafkaProducerMessageHandler. - KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec<K,
V> - Class in org.springframework.integration.kafka.dsl  - 
A
KafkaTemplate-basedKafkaProducerMessageHandlerSpecextension. - KafkaPublishSubscribeChannelSpec - Class in org.springframework.integration.kafka.dsl
 - 
Spec for a publish/subscribe channel backed by an Apache Kafka topic.
 - KafkaPublishSubscribeChannelSpec(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.dsl.KafkaPublishSubscribeChannelSpec
 - KafkaSendFailureException - Exception in org.springframework.integration.kafka.support
 - 
An exception that is the payload of an
ErrorMessagewhen a send fails. - KafkaSendFailureException(Message<?>, ProducerRecord<?, ?>, Throwable) - Constructor for exception org.springframework.integration.kafka.support.KafkaSendFailureException
 - KafkaSubscribableChannelSpec<C extends SubscribableKafkaChannel> - Class in org.springframework.integration.kafka.dsl
 - 
Spec for a subscribable channel.
 - KafkaSubscribableChannelSpec() - Constructor for class org.springframework.integration.kafka.dsl.KafkaSubscribableChannelSpec
 - KafkaTemplateSpec<K,
V> - Class in org.springframework.integration.kafka.dsl  - 
An
IntegrationComponentSpecimplementation for theKafkaTemplate. 
L
- listenerTaskExecutor(AsyncTaskExecutor) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the executor for threads that poll the consumer.
 
M
- messageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
Set the message converter; must be a
RecordMessageConverterorBatchMessageConverterdepending on mode. - messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 - 
Set the message converter to replace the default.
 - messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 - 
Set the message converter to use with a record-based consumer.
 - messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 - 
Set the message converter to use.
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, Pattern) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, Pattern) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, TopicPartitionOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, ContainerProperties, KafkaMessageDrivenChannelAdapter.ListenerMode) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(ConsumerFactory<K, V>, TopicPartitionOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaMessageDrivenChannelAdapterSpec. - messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaMessageDrivenChannelAdapterSpec. - messageKey(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure the message key to store message in Kafka topic.
 - messageKey(Function<Message<P>, ?>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a
Functionthat will be invoked at runtime to determine the message key under which a message will be stored in the topic. - messageKeyExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a SpEL expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.
 - messageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure an
Expressionto determine the Kafka message key to store at runtime against request Message as a root object of evaluation context. 
N
- newAssignment - Variable in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - noAutoAck() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
O
- onInit() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 - 
Specify a
BiConsumerfor seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)call from theKafkaMessageListenerContainer. - onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
Specify a
BiConsumerfor seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)call from theKafkaMessageListenerContainer. - org.springframework.integration.kafka.channel - package org.springframework.integration.kafka.channel
 - 
Provides classes related to message channel implementations for Apache Kafka.
 - org.springframework.integration.kafka.config.xml - package org.springframework.integration.kafka.config.xml
 - 
Provides parser classes to provide Xml namespace support for the Apache Kafka components.
 - org.springframework.integration.kafka.dsl - package org.springframework.integration.kafka.dsl
 - 
Provides Spring Integration Java DSL Components support for Apache Kafka.
 - org.springframework.integration.kafka.inbound - package org.springframework.integration.kafka.inbound
 - 
Provides Spring Integration inbound components for Apache Kafka.
 - org.springframework.integration.kafka.outbound - package org.springframework.integration.kafka.outbound
 - 
Provides Spring Integration outbound components for Apache Kafka.
 - org.springframework.integration.kafka.support - package org.springframework.integration.kafka.support
 - 
Provides support classes.
 - outboundChannelAdapter(KafkaTemplate<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaProducerMessageHandlerSpec. - outboundChannelAdapter(ProducerFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaProducerMessageHandlerSpecwith ProducerFactory. - outboundGateway(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaProducerMessageHandlerSpecwith ProducerFactory. - outboundGateway(ReplyingKafkaTemplate<K, V, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create an initial
KafkaProducerMessageHandlerSpec. 
P
- parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundChannelAdapterParser
 - parseHandler(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 - parseSource(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 - partitionId(Integer) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a partitionId of Kafka topic.
 - partitionId(Function<Message<P>, Integer>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a
Functionthat will be invoked at runtime to determine the partition id under which a message will be stored in the topic. - partitionIdExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a SpEL expression to determine the topic partitionId at runtime against request Message as a root object of evaluation context.
 - partitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure an
Expressionto determine the topic partitionId at runtime against request Message as a root object of evaluation context. - pause() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - pause() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - pause() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - payloadType(Class<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 - 
Set the payload type.
 - payloadType(Class<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
When using a type-aware message converter (such as
StringJsonMessageConverter, set the payload type the converter should create. - pollableChannel(KafkaTemplate<?, ?>, KafkaMessageSource<?, ?>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create a spec for a pollable channel with the provided parameters.
 - PollableKafkaChannel - Class in org.springframework.integration.kafka.channel
 - 
Pollable channel backed by an Apache Kafka topic.
 - PollableKafkaChannel(KafkaOperations<?, ?>, KafkaMessageSource<?, ?>) - Constructor for class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - 
Construct an instance with the provided parameters.
 - pollTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the max time to block in the consumer waiting for records.
 - processSendResult(Message<?>, ProducerRecord<K, V>, CompletableFuture<SendResult<K, V>>, MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - producerListener(ProducerListener<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
 - 
Set a
ProducerListenerwhich will be invoked when Kafka acknowledges a send operation. - producerRecordCreator(KafkaProducerMessageHandler.ProducerRecordCreator<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set a
KafkaProducerMessageHandler.ProducerRecordCreatorto create theProducerRecord. - publishSubscribeChannel(KafkaTemplate<?, ?>, KafkaListenerContainerFactory<?>, String) - Static method in class org.springframework.integration.kafka.dsl.Kafka
 - 
Create a spec for a publish-subscribe channel with the provided parameters.
 - PublishSubscribeKafkaChannel - Class in org.springframework.integration.kafka.channel
 - 
Publish/subscribe channel backed by an Apache Kafka topic.
 - PublishSubscribeKafkaChannel(KafkaOperations<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.channel.PublishSubscribeKafkaChannel
 - 
Construct an instance with the provided parameters.
 
R
- rawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 - 
Set to true to include the raw
ConsumerRecordas headers with keysKafkaHeaders.RAW_DATAandIntegrationMessageHeaderAccessor.SOURCE_DATA. - RawRecordHeaderErrorMessageStrategy - Class in org.springframework.integration.kafka.support
 - 
ErrorMessageStrategyextension that adds the raw record as a header to theErrorMessage. - RawRecordHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
 - receive() - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - receive(long) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - record - Enum constant in enum class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
 - 
Each
Messagewill be converted from a singleConsumerRecord. - recordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
Specify a
RecordFilterStrategyto wrapKafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListenerintoFilteringMessageListenerAdapter. - recordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
Set the message converter to use with a record-based consumer.
 - recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 - 
A
RecoveryCallbackinstance for retry operation; if null, the exception will be thrown to the container after retries are exhausted. - recoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
A
RecoveryCallbackinstance for retry operation; if null, the exception will be thrown to the container after retries are exhausted. - REMAINING_RECORDS - Static variable in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
The number of records remaining from the previous poll.
 - removeInterceptor(int) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - removeInterceptor(ChannelInterceptor) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - replyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec
 - 
Set a message converter for replies (when a gateway).
 - resume() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - resume() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
 - 
Specify a
RetryTemplateinstance to use for retrying deliveries. - retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
 - 
Specify a
RetryTemplateinstance to use for retrying deliveries. 
S
- sendFailureChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set the channel to which failed send results are sent.
 - sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set the channel to which failed send results are sent.
 - sendSuccessChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set the channel to which successful send results are sent.
 - sendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set the channel to which successful send results are sent.
 - sendTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Specify a timeout in milliseconds how long
KafkaProducerMessageHandlershould wait for send operation results. - setAckDeferred(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - setAckDeferred(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - setAckDiscarded(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
A
booleanflag to indicate ifFilteringMessageListenerAdaptershould acknowledge discarded records or not. - setAssignmentDuration(Duration) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the time to wait for partition assignment, when used as a gateway, to determine the default reply-to topic/partition.
 - setAutoStartup(boolean) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - 
Set the auto startup.
 - setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Set the message converter to use with a batch-based consumer.
 - setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
Set to true to bind the source consumer record in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA. - setBindSourceRecord(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Set to true to bind the source consumer record in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA. - setCloseTimeout(Duration) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Set the close timeout - default 30 seconds.
 - setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the error message strategy implementation to use when sending error messages after send failures.
 - setFilterInRetry(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
The
booleanflag to specify the order in which the filter and retry operations are performed. - setFlushExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Specify a SpEL expression that evaluates to a
Booleanto determine whether the producer should be flushed after the send. - setFuturesChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the futures channel.
 - setFuturesChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the futures channel name.
 - setGroupId(String) - Method in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 - 
Set the group id for the consumer; if not set, the bean name will be used.
 - setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the header mapper to use.
 - setInterceptors(List<ChannelInterceptor>) - Method in class org.springframework.integration.kafka.channel.PollableKafkaChannel
 - setMessageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Set the message converter; must be a
RecordMessageConverterorBatchMessageConverterdepending on mode. - setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - 
Set the
RecordMessageConverterto the listener. - setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
Set the message converter; must be a
RecordMessageConverterorBatchMessageConverterdepending on mode. - setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Set the message converter to replace the default
MessagingMessageConverter. - setMessageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
Specify a
BiConsumerfor seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)call from theKafkaMessageListenerContainer. - setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Specify a
BiConsumerfor seeks management duringConsumerSeekAware.onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback)call from theKafkaMessageListenerContainer. - setPartitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
When using a type-aware message converter such as
StringJsonMessageConverter, set the payload type the converter should create. - setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
When using a type-aware message converter such as
StringJsonMessageConverter, set the payload type the converter should create. - setPayloadType(Class<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Set the payload type.
 - setPhase(int) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - 
Set the phase.
 - setProducerRecordCreator(KafkaProducerMessageHandler.ProducerRecordCreator<K, V>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set a
KafkaProducerMessageHandler.ProducerRecordCreatorto create theProducerRecord. - setRawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - 
Set to true to include the raw
ConsumerRecordas headers with keysKafkaHeaders.RAW_DATAandIntegrationMessageHeaderAccessor.SOURCE_DATA. - setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Specify a
RecordFilterStrategyto wrapKafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListenerintoFilteringMessageListenerAdapter. - setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Set the message converter to use with a record-based consumer.
 - setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
A
RecoveryCallbackinstance for retry operation; if null, the exception will be thrown to the container after retries are exhausted (unless an error channel is configured). - setRecoveryCallback(RecoveryCallback<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
A
RecoveryCallbackinstance for retry operation; if null, the exception will be thrown to the container after retries are exhausted (unless an error channel is configured). - setReplyMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set a message converter for gateway replies.
 - setReplyPayloadType(Type) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
When using a type-aware message converter (such as
StringJsonMessageConverter, set the payload type the converter should create. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 - 
Specify a
RetryTemplateinstance to use for retrying deliveries. - setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 - 
Specify a
RetryTemplateinstance to use for retrying deliveries. - setRolledBack(boolean) - Method in interface org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfo
 - setRolledBack(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - setSendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the failure channel.
 - setSendFailureChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the failure channel name.
 - setSendSuccessChannel(MessageChannel) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the success channel.
 - setSendSuccessChannelName(String) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set the Success channel name.
 - setSendTimeout(long) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Specify a timeout in milliseconds for how long this
KafkaProducerMessageHandlershould wait for send operation results. - setSendTimeoutExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Specify a SpEL expression to evaluate a timeout in milliseconds for how long this
KafkaProducerMessageHandlershould wait for send operation results. - setSync(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
A
booleanindicating if theKafkaProducerMessageHandlershould wait for the send operation results or not. - setTimeoutBuffer(int) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set a buffer, in milliseconds, added to the configured
delivery.timeout.msto determine the minimum time to wait for the send future completion whensyncis true. - setTimestampExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Specify a SpEL expression to evaluate a timestamp that will be added in the Kafka record.
 - setTopicExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - setUseTemplateConverter(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - 
Set to true to use the template's message converter to create the
ProducerRecordinstead of theproducerRecordCreator. - shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundChannelAdapterParser
 - shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaInboundGatewayParser
 - shouldGenerateIdAsFallback() - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundGatewayParser
 - shutdownTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set the timeout for shutting down the container.
 - start() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - start() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - start() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - stop() - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - stop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 - stop() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 - stop(Runnable) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - SubscribableKafkaChannel - Class in org.springframework.integration.kafka.channel
 - 
Subscribable channel backed by an Apache Kafka topic.
 - SubscribableKafkaChannel(KafkaOperations<?, ?>, KafkaListenerContainerFactory<?>, String) - Constructor for class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - 
Construct an instance with the provided parameters.
 - subscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - sync(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
A
booleanindicating if theKafkaProducerMessageHandlershould wait for the send operation results or not. - syncCommits(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
 - 
Set whether to call consumer.commitSync() or commitAsync() when the container is responsible for commits.
 
T
- taskScheduler(TaskScheduler) - Method in class org.springframework.integration.kafka.dsl.KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec
 - timestamp(Function<Message<P>, Long>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a
Functionthat will be invoked at runtime to determine the Kafka record timestamp will be stored in the topic. - timestampExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a SpEL expression to determine the timestamp at runtime against a request Message as a root object of evaluation context.
 - timestampExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure an
Expressionto determine the timestamp at runtime against a request Message as a root object of evaluation context. - topic - Variable in class org.springframework.integration.kafka.channel.AbstractKafkaChannel
 - topic(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure the Kafka topic to send messages.
 - topic(Function<Message<P>, String>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a
Functionthat will be invoked at runtime to determine the topic to which a message will be sent. - topicExpression(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure a SpEL expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
 - topicExpression(Expression) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Configure an
Expressionto determine the Kafka topic at runtime against request Message as a root object of evaluation context. - toString() - Method in record class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 - 
Returns a string representation of this record class.
 - toString() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 - toString() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
U
- unsubscribe(MessageHandler) - Method in class org.springframework.integration.kafka.channel.SubscribableKafkaChannel
 - useTemplateConverter(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 - 
Set to true to use the template's message converter to create the
ProducerRecordinstead of theproducerRecordCreator. 
V
- valueOf(String) - Static method in enum class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
 - 
Returns the enum constant of this class with the specified name.
 - values() - Static method in enum class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
 - 
Returns an array containing the constants of this enum class, in the order they are declared.
 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form