Skip navigation links
A B C D E F G H I K M N O P R S T V 

A

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#COUNT or ContainerProperties.AckMode#COUNT_TIME is being used.
ackDiscarded(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
A boolean flag to indicate if FilteringMessageListenerAdapter should 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(AcknowledgmentCallback.Status) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
acknowledge() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
ackOnError(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set whether the container should ack messages that throw exceptions or not.
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#TIME or ContainerProperties.AckMode#COUNT_TIME is being used.
afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
afterShutdown() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 

B

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
 
buildErrorMessage(Throwable, AttributeAccessor) - Method in class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
 

C

clientId(String) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
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.
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 Consumer callback, with a KafkaTemplateSpec argument.
configureKafkaTemplate(Consumer<KafkaTemplateSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
Configure a Kafka Template by invoking the Consumer callback, with a KafkaTemplateSpec argument.
configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a KafkaMessageListenerContainerSpec argument.
configureListenerContainer(Consumer<KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a KafkaMessageListenerContainerSpec argument.
configureTemplate(Consumer<KafkaTemplateSpec<K, R>>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec
Configure a template by invoking the Consumer callback, with a KafkaTemplateSpec argument.
consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the user defined ConsumerRebalanceListener implementation.
consumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set the executor for threads that poll the consumer.
createCallback(KafkaMessageSource.KafkaAckInfo<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 
createConsumer() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 

D

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
 
doReceive() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
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
 

E

errorHandler(GenericErrorHandler<?>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Specify an ErrorHandler for the AbstractMessageListenerContainer.

F

filterInRetry(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
The boolean flag to specify the order how RetryingMessageListenerAdapter and FilteringMessageListenerAdapter are wrapped to each other, if both of them are present.

G

getClientId() - 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
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
getErrorMessageAttributes(Message<?>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
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
 
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
 
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(String) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
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
 
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.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>, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundChannelAdapterSpec with the consumer factory and topics.
inboundChannelAdapter(ConsumerFactory<K, V>, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, String...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundChannelAdapterSpec with the consumer factory and topics with a custom ack callback factory.
inboundGateway(AbstractMessageListenerContainer<K, V>, KafkaTemplate<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundGatewaySpec with the provided container and template.
inboundGateway(ConsumerFactory<K, V>, ContainerProperties, ProducerFactory<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundGatewaySpec with the provided consumer factory, container properties and producer factory.
inboundGateway(KafkaMessageListenerContainerSpec<K, V>, KafkaTemplateSpec<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaInboundGatewaySpec with the provided container and template specs.
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
 
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.inbound.KafkaMessageSource
 

K

Kafka - Class in org.springframework.integration.kafka.dsl
Factory class for Apache Kafka components.
KafkaAckCallback(KafkaMessageSource.KafkaAckInfo<K, V>) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 
KafkaAckCallbackFactory() - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallbackFactory
 
KafkaInboundChannelAdapterSpec<K,V> - Class in org.springframework.integration.kafka.dsl
Spec for a polled Kafka inbound channel adapter.
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.
KafkaInboundGatewaySpec<K,V,R,S extends KafkaInboundGatewaySpec<K,V,R,S>> - Class in org.springframework.integration.kafka.dsl
A MessagingGatewaySpec implementation for the KafkaInboundGateway.
KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
A ConcurrentMessageListenerContainer configuration KafkaInboundGatewaySpec extension.
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
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 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 MessageProducerSpec implementation for the KafkaMessageDrivenChannelAdapter.
KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec<K,V> - Class in org.springframework.integration.kafka.dsl
A ConcurrentMessageListenerContainer configuration KafkaMessageDrivenChannelAdapterSpec extension.
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 kafka.
KafkaMessageSource(ConsumerFactory<K, V>, String...) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
KafkaMessageSource(ConsumerFactory<K, V>, KafkaMessageSource.KafkaAckCallbackFactory<K, V>, String...) - Constructor for class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
KafkaMessageSource.KafkaAckCallback<K,V> - Class in org.springframework.integration.kafka.inbound
AcknowledgmentCallback for Kafka.
KafkaMessageSource.KafkaAckCallbackFactory<K,V> - 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 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
 
KafkaOutboundGatewaySpec<K,V,R,S extends KafkaOutboundGatewaySpec<K,V,R,S>> - Class in org.springframework.integration.kafka.dsl
A MessageHandlerSpec implementation for the KafkaProducerMessageHandler as a gateway.
KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
A KafkaTemplate-based KafkaProducerMessageHandlerSpec extension.
KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K,V,R> - Class in org.springframework.integration.kafka.dsl
An IntegrationComponentSpec implementation for the KafkaTemplate.
KafkaProducerMessageHandler<K,V> - Class in org.springframework.integration.kafka.outbound
Kafka Message Handler; when supplied with a ReplyingKafkaTemplate it is used as the handler in an outbound gateway.
KafkaProducerMessageHandler(KafkaTemplate<K, V>) - Constructor for class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
KafkaProducerMessageHandlerSpec<K,V,S extends KafkaProducerMessageHandlerSpec<K,V,S>> - Class in org.springframework.integration.kafka.dsl
A MessageHandlerSpec implementation for the KafkaProducerMessageHandler.
KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec<K,V> - Class in org.springframework.integration.kafka.dsl
A KafkaTemplate-based KafkaProducerMessageHandlerSpec extension.
KafkaSendFailureException - Exception in org.springframework.integration.kafka.support
An exception that is the payload of an ErrorMessage when a send fails.
KafkaSendFailureException(Message<?>, ProducerRecord<?, ?>, Throwable) - Constructor for exception org.springframework.integration.kafka.support.KafkaSendFailureException
 
KafkaTemplateSpec<K,V> - Class in org.springframework.integration.kafka.dsl
An IntegrationComponentSpec implementation for the KafkaTemplate.

M

messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
Set the message converter to use with a record-based consumer.
messageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending on mode.
messageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaTemplateSpec
Set the message converter to use.
messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(AbstractMessageListenerContainer<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode) - 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>, TopicPartitionInitialOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, KafkaMessageDrivenChannelAdapter.ListenerMode, TopicPartitionInitialOffset...) - Static method in class org.springframework.integration.kafka.dsl.Kafka
messageDrivenChannelAdapter(ConsumerFactory<K, V>, String...) - 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>, Pattern) - 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
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 Function that will be invoked at run time 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 Expression to determine the Kafka message key to store at runtime against request Message as a root object of evaluation context.

N

noAutoAck() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckCallback
 

O

onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
 
onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
onPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
org.springframework.integration.kafka.config.xml - package org.springframework.integration.kafka.config.xml
Provides parser classes to provide Xml namespace support for the Kafka components.
org.springframework.integration.kafka.dsl - package org.springframework.integration.kafka.dsl
Provides Kafka Components support for Spring Integration Java DSL.
org.springframework.integration.kafka.inbound - package org.springframework.integration.kafka.inbound
Provides inbound Spring Integration Kafka components.
org.springframework.integration.kafka.outbound - package org.springframework.integration.kafka.outbound
Provides outbound Spring Integration Kafka components.
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
outboundChannelAdapter(ProducerFactory<K, V>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaProducerMessageHandlerSpec with ProducerFactory.
outboundGateway(ReplyingKafkaTemplate<K, V, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
outboundGateway(ProducerFactory<K, V>, GenericMessageListenerContainer<K, R>) - Static method in class org.springframework.integration.kafka.dsl.Kafka
Create an initial KafkaProducerMessageHandlerSpec with ProducerFactory.

P

parseConsumer(Element, ParserContext) - Method in class org.springframework.integration.kafka.config.xml.KafkaOutboundChannelAdapterParser
 
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 Function that will be invoked at run time 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 Expression to 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.KafkaMessageDrivenChannelAdapter
 
payloadType(Type) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
pollTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
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>, ListenableFuture<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 ProducerListener which will be invoked when Kafka acknowledges a send operation.

R

rawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
RawRecordHeaderErrorMessageStrategy - Class in org.springframework.integration.kafka.support
ErrorMessageStrategy extension that adds the raw record as a header to the ErrorMessage.
RawRecordHeaderErrorMessageStrategy() - Constructor for class org.springframework.integration.kafka.support.RawRecordHeaderErrorMessageStrategy
 
rebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundChannelAdapterSpec
 
recordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a RecordFilterStrategy to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into FilteringMessageListenerAdapter.
recordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Set the message converter to use with a record-based consumer.
recoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
recoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
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.KafkaMessageDrivenChannelAdapter
 
retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaInboundGatewaySpec
Specify a RetryTemplate instance to wrap KafkaInboundGateway.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a RetryTemplate instance to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.

S

sendFailureChannel(MessageChannel) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which failed send results are sent.
sendFailureChannel(String) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Set the channel to which failed 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.
sendSuccessChannel(String) - 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 KafkaProducerMessageHandler should wait 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 boolean flag to indicate if FilteringMessageListenerAdapter should acknowledge discarded records or not.
setBatchMessageConverter(BatchMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter to use with a batch-based consumer.
setClientId(String) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the client.id property for the consumer.
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 boolean flag to specify the order how RetryingMessageListenerAdapter and FilteringMessageListenerAdapter are wrapped to each other, if both of them are present.
setGroupId(String) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the group.id property for the consumer.
setHeaderMapper(KafkaHeaderMapper) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
Set the header mapper to use.
setMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending on mode.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending 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 BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
setOnPartitionsAssignedSeekCallback(BiConsumer<Map<TopicPartition, Long>, ConsumerSeekAware.ConsumerSeekCallback>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a BiConsumer for seeks management during ConsumerSeekAware.ConsumerSeekCallback#onPartitionsAssigned(Map, ConsumerSeekAware.ConsumerSeekCallback) call from the KafkaMessageListenerContainer.
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(Type) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the payload type.
setPollTimeout(long) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set the pollTimeout for the poll() operations; default 50ms.
setRawMessageHeader(boolean) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set to true to include the raw ConsumerRecord as a header with key KafkaHeaders.RAW_DATA, enabling callers to have access to the record to process errors.
setRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
Set a rebalance listener.
setRecordFilterStrategy(RecordFilterStrategy<K, V>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a RecordFilterStrategy to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into FilteringMessageListenerAdapter.
setRecordMessageConverter(RecordMessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter to use with a record-based consumer.
setRecoveryCallback(RecoveryCallback<? extends Object>) - Method in class org.springframework.integration.kafka.inbound.KafkaInboundGateway
A RecoveryCallback instance 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<? extends Object>) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
A RecoveryCallback instance 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 RetryTemplate instance to wrap KafkaInboundGateway.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a RetryTemplate instance to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
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 KafkaProducerMessageHandler should wait 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 KafkaProducerMessageHandler should wait wait for send operation results.
setSync(boolean) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
A boolean indicating if the KafkaProducerMessageHandler should wait for the send operation results or not.
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
 
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.inbound.KafkaMessageSource
 
stop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource
 
sync(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
A boolean indicating if the KafkaProducerMessageHandler should wait for the send operation results or not.
syncCommits(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageListenerContainerSpec
Set whether or not to call consumer.commitSync() or commitAsync() when the container is responsible for commits.

T

timestamp(Function<Message<P>, Long>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
Configure a Function that will be invoked at run time 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 Expression to determine the timestamp at runtime against a request Message as a root object of evaluation context.
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 Function that will be invoked at run time 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 Expression to determine the Kafka topic at runtime against request Message as a root object of evaluation context.
toString() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageSource.KafkaAckInfoImpl
 
toString() - Method in exception org.springframework.integration.kafka.support.KafkaSendFailureException
 

V

valueOf(String) - Static method in enum org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter.ListenerMode
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D E F G H I K M N O P R S T V 
Skip navigation links