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

A

ackCount(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the number of outstanding record count after which offsets should be committed when AbstractMessageListenerContainer.AckMode#COUNT or AbstractMessageListenerContainer.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(AbstractMessageListenerContainer.AckMode) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the ack mode to use when auto ack (in the configuration properties) is false.
ackOnError(boolean) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set whether the container should ack messages that throw exceptions or not.
ackTime(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the time (ms) after which outstanding offsets should be committed when AbstractMessageListenerContainer.AckMode#TIME or AbstractMessageListenerContainer.AckMode#COUNT_TIME is being used.
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.KafkaMessageDrivenChannelAdapter
 

C

commitCallback(OffsetCommitCallback) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the commit callback; by default a simple logging callback is used to log success at DEBUG level and failures at ERROR level.
concurrency(int) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Specify a concurrency maximum number for the AbstractMessageListenerContainer.
configureListenerContainer(Consumer<KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec<K, V>>) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
Configure a listener container by invoking the Consumer callback, with a KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec argument.
consumerRebalanceListener(ConsumerRebalanceListener) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the user defined ConsumerRebalanceListener implementation.
consumerTaskExecutor(AsyncListenableTaskExecutor) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the executor for threads that poll the consumer.

D

doParse(Element, ParserContext, String) - Method in class org.springframework.integration.kafka.config.xml.KafkaMessageDrivenChannelAdapterParser
 
doStart() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
doStop() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 

E

errorHandler(ErrorHandler) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.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

getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec
 
getComponentsToRegister() - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
getComponentType() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
getComponentType() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
getKafkaTemplate() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 

H

handleMessageInternal(Message<?>) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 

I

idleEventInterval(Long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.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.
init() - Method in class org.springframework.integration.kafka.config.xml.KafkaNamespaceHandler
 

K

Kafka - Class in org.springframework.integration.kafka.dsl
Factory class for Apache Kafka 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
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.
KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec<K,V> - Class in org.springframework.integration.kafka.dsl
A helper class in the Builder pattern style to delegate options to the ConcurrentMessageListenerContainer.
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
 
KafkaProducerMessageHandler<K,V> - Class in org.springframework.integration.kafka.outbound
Kafka Message Handler.
KafkaProducerMessageHandler(KafkaTemplate<K, V>) - Constructor for class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
KafkaProducerMessageHandlerSpec<K,V> - 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.
kafkaTemplate - Variable in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec
 

M

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.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 
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.

O

onInit() - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
 
onInit() - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
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
 
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.

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.
pollTimeout(long) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the max time to block in the consumer waiting for records.
producerListener(ProducerListener<K, V>) - Method in class org.springframework.integration.kafka.dsl.KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec
 

R

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<Void>) - 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.
retryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.dsl.KafkaMessageDrivenChannelAdapterSpec
Specify a RetryTemplate instance to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.

S

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.
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.
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.
setMessageConverter(MessageConverter) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Set the message converter; must be a RecordMessageConverter or BatchMessageConverter depending on mode.
setMessageKeyExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
setPartitionIdExpression(Expression) - Method in class org.springframework.integration.kafka.outbound.KafkaProducerMessageHandler
 
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.
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.KafkaMessageDrivenChannelAdapter
A RecoveryCallback instance for retry operation; if null, the exception will be thrown to the container after retries are exhausted.
setRetryTemplate(RetryTemplate) - Method in class org.springframework.integration.kafka.inbound.KafkaMessageDrivenChannelAdapter
Specify a RetryTemplate instance to wrap KafkaMessageDrivenChannelAdapter.IntegrationRecordMessageListener into RetryingMessageListenerAdapter.
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.KafkaMessageDrivenChannelAdapterSpec.KafkaMessageListenerContainerSpec
Set the timeout for shutting down the container.
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.KafkaMessageDrivenChannelAdapterSpec.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.

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 O P R S T V 
Skip navigation links