Apache Kafka 支持
概述
用于 Apache Kafka 的 Spring 集成基于 用于 Apache Kafka 的 Spring 项目。
您需要将此依赖项包含到您的项目中
-
Maven
-
Gradle
<dependency>
<groupId>org.springframework.integration</groupId>
<artifactId>spring-integration-kafka</artifactId>
<version>6.3.5</version>
</dependency>
compile "org.springframework.integration:spring-integration-kafka:6.3.5"
它提供以下组件
出站通道适配器
出站通道适配器用于将消息从 Spring 集成通道发布到 Apache Kafka 主题。通道在应用程序上下文中定义,然后连接到将消息发送到 Apache Kafka 的应用程序。发送方应用程序可以使用 Spring 集成消息发布到 Apache Kafka,这些消息在内部由出站通道适配器转换为 Kafka 记录,如下所示:
-
Spring 集成消息的有效负载用于填充 Kafka 记录的有效负载。
-
默认情况下,Spring 集成消息的
kafka_messageKey
标头用于填充 Kafka 记录的键。
您可以分别通过kafka_topic
和kafka_partitionId
标头自定义目标主题和分区以发布消息。
此外,<int-kafka:outbound-channel-adapter>
提供了通过对出站消息应用 SpEL 表达式来提取键、目标主题和目标分区的功能。为此,它支持三对相互排斥的属性:
-
topic
和topic-expression
-
message-key
和message-key-expression
-
partition-id
和partition-id-expression
这些允许您分别将topic
、message-key
和partition-id
指定为适配器上的静态值,或者在运行时针对请求消息动态评估其值。
KafkaHeaders 接口(由spring-kafka 提供)包含用于与标头交互的常量。messageKey 和topic 默认标头现在需要kafka_ 前缀。从使用旧标头的早期版本迁移时,您需要在<int-kafka:outbound-channel-adapter> 上指定message-key-expression="headers['messageKey']" 和topic-expression="headers['topic']" 。或者,您可以使用<header-enricher> 或MessageBuilder 将标头上游更改为来自KafkaHeaders 的新标头。如果您使用常量值,也可以使用topic 和message-key 在适配器上配置它们。 |
注意:如果适配器配置了主题或消息键(使用常量或表达式),则使用这些键,并忽略相应的标头。如果您希望标头覆盖配置,则需要在表达式中配置它,例如:
topic-expression="headers['topic'] != null ? headers['topic'] : 'myTopic'"
适配器需要一个KafkaTemplate
,而KafkaTemplate
又需要一个配置合适的KafkaProducerFactory
。
如果提供了send-failure-channel
(sendFailureChannel
)并且接收到send()
失败(同步或异步),则会将ErrorMessage
发送到通道。有效负载是KafkaSendFailureException
,具有failedMessage
、record
(ProducerRecord
)和cause
属性。您可以通过设置error-message-strategy
属性来覆盖DefaultErrorMessageStrategy
。
如果提供了send-success-channel
(sendSuccessChannel
),则在成功发送后会发送一个有效负载类型为org.apache.kafka.clients.producer.RecordMetadata
的消息。
如果您的应用程序使用事务,并且使用相同的通道适配器发布事务由侦听器容器启动的消息,以及发布没有现有事务的消息,则必须在KafkaTemplate 上配置transactionIdPrefix 以覆盖容器或事务管理器使用的前缀。由容器启动的事务(生产者工厂或事务管理器属性)使用的前缀必须在所有应用程序实例上相同。用于仅生产者事务的前缀必须在所有应用程序实例上唯一。 |
您可以配置一个flushExpression
,它必须解析为布尔值。如果您使用linger.ms
和batch.size
Kafka 生产者属性,则发送几条消息后刷新可能很有用;表达式应该在最后一条消息上计算为Boolean.TRUE
,并且不完整的批次将立即发送。默认情况下,表达式在KafkaIntegrationHeaders.FLUSH
标头(kafka_flush
)中查找Boolean
值。如果值为true
,则会发生刷新,如果值为false
或标头不存在,则不会发生刷新。
KafkaProducerMessageHandler.sendTimeoutExpression
的默认值已从 10 秒更改为delivery.timeout.ms
Kafka 生产者属性+ 5000
,以便将超时后的实际 Kafka 错误传播到应用程序,而不是由此框架生成的超时。此更改是为了保持一致性,因为您可能会遇到意外行为(Spring 可能会超时发送,而实际上它最终可能会成功)。重要提示:默认情况下,该超时时间为 120 秒,因此您可能希望将其缩短以获得更及时的失败。
配置
以下示例显示了如何为 Apache Kafka 配置出站通道适配器
-
Java DSL
-
Java
-
XML
@Bean
public ProducerFactory<Integer, String> producerFactory() {
return new DefaultKafkaProducerFactory<>(KafkaTestUtils.producerProps(embeddedKafka));
}
@Bean
public IntegrationFlow sendToKafkaFlow() {
return f -> f
.splitWith(s -> s.<String>function(p -> Stream.generate(() -> p).limit(101).iterator()))
.publishSubscribeChannel(c -> c
.subscribe(sf -> sf.handle(
kafkaMessageHandler(producerFactory(), TEST_TOPIC1)
.timestampExpression("T(Long).valueOf('1487694048633')"),
e -> e.id("kafkaProducer1")))
.subscribe(sf -> sf.handle(
kafkaMessageHandler(producerFactory(), TEST_TOPIC2)
.timestamp(m -> 1487694048644L),
e -> e.id("kafkaProducer2")))
);
}
@Bean
public DefaultKafkaHeaderMapper mapper() {
return new DefaultKafkaHeaderMapper();
}
private KafkaProducerMessageHandlerSpec<Integer, String, ?> kafkaMessageHandler(
ProducerFactory<Integer, String> producerFactory, String topic) {
return Kafka
.outboundChannelAdapter(producerFactory)
.messageKey(m -> m
.getHeaders()
.get(IntegrationMessageHeaderAccessor.SEQUENCE_NUMBER))
.headerMapper(mapper())
.partitionId(m -> 10)
.topicExpression("headers[kafka_topic] ?: '" + topic + "'")
.configureKafkaTemplate(t -> t.id("kafkaTemplate:" + topic));
}
@Bean
@ServiceActivator(inputChannel = "toKafka")
public MessageHandler handler() throws Exception {
KafkaProducerMessageHandler<String, String> handler =
new KafkaProducerMessageHandler<>(kafkaTemplate());
handler.setTopicExpression(new LiteralExpression("someTopic"));
handler.setMessageKeyExpression(new LiteralExpression("someKey"));
handler.setSuccessChannel(successes());
handler.setFailureChannel(failures());
return handler;
}
@Bean
public KafkaTemplate<String, String> kafkaTemplate() {
return new KafkaTemplate<>(producerFactory());
}
@Bean
public ProducerFactory<String, String> producerFactory() {
Map<String, Object> props = new HashMap<>();
props.put(ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, this.brokerAddress);
// set more properties
return new DefaultKafkaProducerFactory<>(props);
}
<int-kafka:outbound-channel-adapter id="kafkaOutboundChannelAdapter"
kafka-template="template"
auto-startup="false"
channel="inputToKafka"
topic="foo"
sync="false"
message-key-expression="'bar'"
send-failure-channel="failures"
send-success-channel="successes"
error-message-strategy="ems"
partition-id-expression="2">
</int-kafka:outbound-channel-adapter>
<bean id="template" class="org.springframework.kafka.core.KafkaTemplate">
<constructor-arg>
<bean class="org.springframework.kafka.core.DefaultKafkaProducerFactory">
<constructor-arg>
<map>
<entry key="bootstrap.servers" value="localhost:9092" />
... <!-- more producer properties -->
</map>
</constructor-arg>
</bean>
</constructor-arg>
</bean>
消息驱动的通道适配器
KafkaMessageDrivenChannelAdapter
(<int-kafka:message-driven-channel-adapter>
)使用spring-kafka
KafkaMessageListenerContainer
或ConcurrentListenerContainer
。
此外,mode
属性可用。它可以接受record
或batch
的值(默认值:record
)。对于record
模式,每个消息有效负载都从单个ConsumerRecord
转换。对于batch
模式,有效负载是从消费者轮询返回的所有ConsumerRecord
实例转换的对象列表。与批处理@KafkaListener
一样,KafkaHeaders.RECEIVED_KEY
、KafkaHeaders.RECEIVED_PARTITION
、KafkaHeaders.RECEIVED_TOPIC
和KafkaHeaders.OFFSET
标头也是列表,其位置对应于有效负载中的位置。
接收到的消息填充了某些标头。有关更多信息,请参阅KafkaHeaders
类。
Consumer 对象(在kafka_consumer 标头中)不是线程安全的。您必须仅在调用适配器内侦听器的线程上调用其方法。如果您将消息交给另一个线程,则不得调用其方法。 |
当提供retry-template
时,将根据其重试策略重试传递失败。如果也提供了error-channel
,则在重试耗尽后将使用默认的ErrorMessageSendingRecoverer
作为恢复回调。您也可以使用recovery-callback
指定在这种情况下要采取的其他操作,或者将其设置为null
以将最终异常抛出到侦听器容器,以便在那里处理它。
构建ErrorMessage
(用于error-channel
或recovery-callback
)时,您可以通过设置error-message-strategy
属性来自定义错误消息。默认情况下,使用RawRecordHeaderErrorMessageStrategy
来访问转换后的消息以及原始ConsumerRecord
。
这种形式的重试是阻塞式的,如果所有轮询记录的总重试延迟可能超过max.poll.interval.ms 消费者属性,则可能会导致重新平衡。相反,考虑向侦听器容器添加DefaultErrorHandler ,并配置KafkaErrorSendingMessageRecoverer 。 |
配置
以下示例显示了如何配置消息驱动的通道适配器
-
Java DSL
-
Java
-
XML
@Bean
public IntegrationFlow topic1ListenerFromKafkaFlow() {
return IntegrationFlow
.from(Kafka.messageDrivenChannelAdapter(consumerFactory(),
KafkaMessageDrivenChannelAdapter.ListenerMode.record, TEST_TOPIC1)
.configureListenerContainer(c ->
c.ackMode(AbstractMessageListenerContainer.AckMode.MANUAL)
.id("topic1ListenerContainer"))
.recoveryCallback(new ErrorMessageSendingRecoverer(errorChannel(),
new RawRecordHeaderErrorMessageStrategy()))
.retryTemplate(new RetryTemplate())
.filterInRetry(true))
.filter(Message.class, m ->
m.getHeaders().get(KafkaHeaders.RECEIVED_MESSAGE_KEY, Integer.class) < 101,
f -> f.throwExceptionOnRejection(true))
.<String, String>transform(String::toUpperCase)
.channel(c -> c.queue("listeningFromKafkaResults1"))
.get();
}
@Bean
public KafkaMessageDrivenChannelAdapter<String, String>
adapter(KafkaMessageListenerContainer<String, String> container) {
KafkaMessageDrivenChannelAdapter<String, String> kafkaMessageDrivenChannelAdapter =
new KafkaMessageDrivenChannelAdapter<>(container, ListenerMode.record);
kafkaMessageDrivenChannelAdapter.setOutputChannel(received());
return kafkaMessageDrivenChannelAdapter;
}
@Bean
public KafkaMessageListenerContainer<String, String> container() throws Exception {
ContainerProperties properties = new ContainerProperties(this.topic);
// set more properties
return new KafkaMessageListenerContainer<>(consumerFactory(), properties);
}
@Bean
public ConsumerFactory<String, String> consumerFactory() {
Map<String, Object> props = new HashMap<>();
props.put(ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG, this.brokerAddress);
// set more properties
return new DefaultKafkaConsumerFactory<>(props);
}
<int-kafka:message-driven-channel-adapter
id="kafkaListener"
listener-container="container1"
auto-startup="false"
phase="100"
send-timeout="5000"
mode="record"
retry-template="template"
recovery-callback="callback"
error-message-strategy="ems"
channel="someChannel"
error-channel="errorChannel" />
<bean id="container1" class="org.springframework.kafka.listener.KafkaMessageListenerContainer">
<constructor-arg>
<bean class="org.springframework.kafka.core.DefaultKafkaConsumerFactory">
<constructor-arg>
<map>
<entry key="bootstrap.servers" value="localhost:9092" />
...
</map>
</constructor-arg>
</bean>
</constructor-arg>
<constructor-arg>
<bean class="org.springframework.kafka.listener.config.ContainerProperties">
<constructor-arg name="topics" value="foo" />
</bean>
</constructor-arg>
</bean>
您还可以使用用于@KafkaListener
注释的容器工厂创建用于其他用途的ConcurrentMessageListenerContainer
实例。有关示例,请参阅用于 Apache Kafka 的 Spring 文档。
使用 Java DSL,容器不必配置为@Bean
,因为 DSL 将容器注册为 bean。以下示例显示了如何操作:
@Bean
public IntegrationFlow topic2ListenerFromKafkaFlow() {
return IntegrationFlow
.from(Kafka.messageDrivenChannelAdapter(kafkaListenerContainerFactory().createContainer(TEST_TOPIC2),
KafkaMessageDrivenChannelAdapter.ListenerMode.record)
.id("topic2Adapter"))
...
get();
}
请注意,在这种情况下,适配器被赋予了一个id
(topic2Adapter
)。容器在应用程序上下文中使用名称topic2Adapter.container
注册。如果适配器没有id
属性,则容器的 bean 名称是容器的完全限定类名加上#n
,其中n
为每个容器递增。
入站通道适配器
KafkaMessageSource
提供了一个可轮询的通道适配器实现。
配置
-
Java DSL
-
Kotlin
-
Java
-
XML
@Bean
public IntegrationFlow flow(ConsumerFactory<String, String> cf) {
return IntegrationFlow.from(Kafka.inboundChannelAdapter(cf, new ConsumerProperties("myTopic")),
e -> e.poller(Pollers.fixedDelay(5000)))
.handle(System.out::println)
.get();
}
@Bean
fun sourceFlow(cf: ConsumerFactory<String, String>) =
integrationFlow(Kafka.inboundChannelAdapter(cf,
ConsumerProperties(TEST_TOPIC3).also {
it.groupId = "kotlinMessageSourceGroup"
}),
{ poller(Pollers.fixedDelay(100)) }) {
handle { m ->
}
}
@InboundChannelAdapter(channel = "fromKafka", poller = @Poller(fixedDelay = "5000"))
@Bean
public KafkaMessageSource<String, String> source(ConsumerFactory<String, String> cf) {
ConsumerProperties consumerProperties = new ConsumerProperties("myTopic");
consumerProperties.setGroupId("myGroupId");
consumerProperties.setClientId("myClientId");
retunr new KafkaMessageSource<>(cf, consumerProperties);
}
<int-kafka:inbound-channel-adapter
id="adapter1"
consumer-factory="consumerFactory"
consumer-properties="consumerProperties1"
ack-factory="ackFactory"
channel="inbound"
message-converter="converter"
payload-type="java.lang.String"
raw-header="true"
auto-startup="false">
<int:poller fixed-delay="5000"/>
</int-kafka:inbound-channel-adapter>
<bean id="consumerFactory" class="org.springframework.kafka.core.DefaultKafkaConsumerFactory">
<constructor-arg>
<map>
<entry key="max.poll.records" value="1"/>
</map>
</constructor-arg>
</bean>
<bean id="consumerProperties1" class="org.springframework.kafka.listener.ConsumerProperties">
<constructor-arg name="topics" value="topic1"/>
<property name="groupId" value="group"/>
<property name="clientId" value="client"/>
</bean>
请参考 javadoc 以了解可用的属性。
默认情况下,必须在消费者工厂中显式设置max.poll.records
,否则如果消费者工厂是DefaultKafkaConsumerFactory
,它将强制设置为 1。您可以将属性allowMultiFetch
设置为true
来覆盖此行为。
为避免重新平衡,必须在max.poll.interval.ms 内轮询消费者。如果将allowMultiFetch 设置为true ,则必须在max.poll.interval.ms 内处理所有检索到的记录并再次轮询。 |
此适配器发出的消息包含一个名为kafka_remainingRecords
的报头,其中包含上次轮询剩余记录的数量。
从版本6.2
开始,KafkaMessageSource
支持在消费者属性中提供的ErrorHandlingDeserializer
。一个DeserializationException
从记录报头中提取并抛给调用者。对于SourcePollingChannelAdapter
,此异常将包装到ErrorMessage
中并发布到其errorChannel
。有关更多信息,请参见ErrorHandlingDeserializer
文档。
出站网关
出站网关用于请求/回复操作。它与大多数Spring Integration网关的不同之处在于,发送线程不会阻塞在网关中,并且回复在回复侦听器容器线程上处理。如果您的代码在同步消息网关之后调用网关,则用户线程将在那里阻塞,直到收到回复(或超时)。
在回复容器已分配其主题和分区之前,网关不接受请求。建议您向模板的回复容器属性添加ConsumerRebalanceListener ,并在发送消息到网关之前等待onPartitionsAssigned 调用。 |
KafkaProducerMessageHandler
的sendTimeoutExpression
默认值为Kafka生产者属性delivery.timeout.ms
+ 5000
,以便将超时后的实际Kafka错误传播到应用程序,而不是此框架生成的超时。由于您可能会遇到意外行为(Spring可能会超时send()
,而实际上最终会成功),因此已更改此设置以保持一致性。重要提示:默认情况下,该超时时间为120秒,因此您可能希望将其缩短以获得更及时的故障。
配置
以下示例显示如何配置网关
-
Java DSL
-
Java
-
XML
@Bean
public IntegrationFlow outboundGateFlow(
ReplyingKafkaTemplate<String, String, String> kafkaTemplate) {
return IntegrationFlow.from("kafkaRequests")
.handle(Kafka.outboundGateway(kafkaTemplate))
.channel("kafkaReplies")
.get();
}
@Bean
@ServiceActivator(inputChannel = "kafkaRequests", outputChannel = "kafkaReplies")
public KafkaProducerMessageHandler<String, String> outGateway(
ReplyingKafkaTemplate<String, String, String> kafkaTemplate) {
return new KafkaProducerMessageHandler<>(kafkaTemplate);
}
<int-kafka:outbound-gateway
id="allProps"
error-message-strategy="ems"
kafka-template="template"
message-key-expression="'key'"
order="23"
partition-id-expression="2"
reply-channel="replies"
reply-timeout="43"
request-channel="requests"
requires-reply="false"
send-success-channel="successes"
send-failure-channel="failures"
send-timeout-expression="44"
sync="true"
timestamp-expression="T(System).currentTimeMillis()"
topic-expression="'topic'"/>
请参考 javadoc 以了解可用的属性。
请注意,使用了与出站通道适配器相同的类,唯一的区别是传递给构造函数的KafkaTemplate
是ReplyingKafkaTemplate
。有关更多信息,请参见Apache Kafka 的 Spring 文档。
出站主题、分区、键等与出站适配器确定方式相同。回复主题的确定方式如下:
-
验证名为
KafkaHeaders.REPLY_TOPIC
的消息报头(如果存在,则必须具有String
或byte[]
值)是否与模板的回复容器的已订阅主题匹配。 -
如果模板的
replyContainer
只订阅了一个主题,则使用该主题。
您还可以指定KafkaHeaders.REPLY_PARTITION
报头来确定要用于回复的特定分区。同样,这也会针对模板的回复容器的订阅进行验证。
或者,您还可以使用类似于以下bean的配置
@Bean
public IntegrationFlow outboundGateFlow() {
return IntegrationFlow.from("kafkaRequests")
.handle(Kafka.outboundGateway(producerFactory(), replyContainer())
.configureKafkaTemplate(t -> t.replyTimeout(30_000)))
.channel("kafkaReplies")
.get();
}
入站网关
入站网关用于请求/回复操作。
配置
以下示例显示如何配置入站网关
-
Java DSL
-
Java
-
XML
@Bean
public IntegrationFlow serverGateway(
ConcurrentMessageListenerContainer<Integer, String> container,
KafkaTemplate<Integer, String> replyTemplate) {
return IntegrationFlow
.from(Kafka.inboundGateway(container, replyTemplate)
.replyTimeout(30_000))
.<String, String>transform(String::toUpperCase)
.get();
}
@Bean
public KafkaInboundGateway<Integer, String, String> inboundGateway(
AbstractMessageListenerContainer<Integer, String>container,
KafkaTemplate<Integer, String> replyTemplate) {
KafkaInboundGateway<Integer, String, String> gateway =
new KafkaInboundGateway<>(container, replyTemplate);
gateway.setRequestChannel(requests);
gateway.setReplyChannel(replies);
gateway.setReplyTimeout(30_000);
return gateway;
}
<int-kafka:inbound-gateway
id="gateway1"
listener-container="container1"
kafka-template="template"
auto-startup="false"
phase="100"
request-timeout="5000"
request-channel="nullChannel"
reply-channel="errorChannel"
reply-timeout="43"
message-converter="messageConverter"
payload-type="java.lang.String"
error-message-strategy="ems"
retry-template="retryTemplate"
recovery-callback="recoveryCallback"/>
请参考 javadoc 以了解可用的属性。
提供RetryTemplate
时,将根据其重试策略重试传递失败。如果也提供了error-channel
,则在重试耗尽后将使用默认的ErrorMessageSendingRecoverer
作为恢复回调。您还可以使用recovery-callback
指定在这种情况下要采取的其他操作,或将其设置为null
以将最终异常抛给侦听器容器,以便在那里进行处理。
构建ErrorMessage
(用于error-channel
或recovery-callback
)时,您可以通过设置error-message-strategy
属性来自定义错误消息。默认情况下,使用RawRecordHeaderErrorMessageStrategy
来访问转换后的消息以及原始ConsumerRecord
。
这种形式的重试是阻塞式的,如果所有轮询记录的总重试延迟可能超过max.poll.interval.ms 消费者属性,则可能会导致重新平衡。相反,考虑向侦听器容器添加DefaultErrorHandler ,并配置KafkaErrorSendingMessageRecoverer 。 |
以下示例显示如何使用Java DSL配置简单的字母大写转换器
或者,您可以使用类似于以下代码配置字母大写转换器
@Bean
public IntegrationFlow serverGateway() {
return IntegrationFlow
.from(Kafka.inboundGateway(consumerFactory(), containerProperties(),
producerFactory())
.replyTimeout(30_000))
.<String, String>transform(String::toUpperCase)
.get();
}
您还可以使用用于@KafkaListener
注释的容器工厂创建用于其他目的的ConcurrentMessageListenerContainer
实例。有关示例,请参见Apache Kafka 的 Spring 文档和消息驱动的通道适配器。
由Apache Kafka主题支持的通道
Spring Integration具有由Apache Kafka主题支持的持久性MessageChannel
实现。
每个通道都需要一个用于发送端的KafkaTemplate
,以及一个侦听器容器工厂(对于可订阅通道)或一个KafkaMessageSource
(对于可轮询通道)。
Java DSL配置
-
Java DSL
-
Java
-
XML
@Bean
public IntegrationFlow flowWithSubscribable(KafkaTemplate<Integer, String> template,
ConcurrentKafkaListenerContainerFactory<Integer, String> containerFactory) {
return IntegrationFlow.from(...)
...
.channel(Kafka.channel(template, containerFactory, "someTopic1").groupId("group1"))
...
.get();
}
@Bean
public IntegrationFlow flowWithPubSub(KafkaTemplate<Integer, String> template,
ConcurrentKafkaListenerContainerFactory<Integer, String> containerFactory) {
return IntegrationFlow.from(...)
...
.publishSubscribeChannel(pubSub(template, containerFactory),
pubsub -> pubsub
.subscribe(subflow -> ...)
.subscribe(subflow -> ...))
.get();
}
@Bean
public BroadcastCapableChannel pubSub(KafkaTemplate<Integer, String> template,
ConcurrentKafkaListenerContainerFactory<Integer, String> containerFactory) {
return Kafka.publishSubscribeChannel(template, containerFactory, "someTopic2")
.groupId("group2")
.get();
}
@Bean
public IntegrationFlow flowWithPollable(KafkaTemplate<Integer, String> template,
KafkaMessageSource<Integer, String> source) {
return IntegrationFlow.from(...)
...
.channel(Kafka.pollableChannel(template, source, "someTopic3").groupId("group3"))
.handle(..., e -> e.poller(...))
...
.get();
}
/**
* Channel for a single subscriber.
**/
@Bean
SubscribableKafkaChannel pointToPoint(KafkaTemplate<String, String> template,
KafkaListenerContainerFactory<String, String> factory)
SubscribableKafkaChannel channel =
new SubscribableKafkaChannel(template, factory, "topicA");
channel.setGroupId("group1");
return channel;
}
/**
* Channel for multiple subscribers.
**/
@Bean
SubscribableKafkaChannel pubsub(KafkaTemplate<String, String> template,
KafkaListenerContainerFactory<String, String> factory)
SubscribableKafkaChannel channel =
new SubscribableKafkaChannel(template, factory, "topicB", true);
channel.setGroupId("group2");
return channel;
}
/**
* Pollable channel (topic is configured on the source)
**/
@Bean
PollableKafkaChannel pollable(KafkaTemplate<String, String> template,
KafkaMessageSource<String, String> source)
PollableKafkaChannel channel =
new PollableKafkaChannel(template, source);
channel.setGroupId("group3");
return channel;
}
<int-kafka:channel kafka-template="template" id="ptp" topic="ptpTopic" group-id="ptpGroup"
container-factory="containerFactory" />
<int-kafka:pollable-channel kafka-template="template" id="pollable" message-source="source"
group-id = "pollableGroup"/>
<int-kafka:publish-subscribe-channel kafka-template="template" id="pubSub" topic="pubSubTopic"
group-id="pubSubGroup" container-factory="containerFactory" />
消息转换
提供了一个StringJsonMessageConverter
。有关更多信息,请参见Apache Kafka 的 Spring 文档。
在将此转换器与消息驱动的通道适配器一起使用时,您可以指定要将传入有效负载转换到的类型。这是通过在适配器上设置payload-type
属性(payloadType
属性)来实现的。以下示例显示如何在XML配置中执行此操作
<int-kafka:message-driven-channel-adapter
id="kafkaListener"
listener-container="container1"
auto-startup="false"
phase="100"
send-timeout="5000"
channel="nullChannel"
message-converter="messageConverter"
payload-type="com.example.Thing"
error-channel="errorChannel" />
<bean id="messageConverter"
class="org.springframework.kafka.support.converter.MessagingMessageConverter"/>
以下示例显示如何在Java配置中设置适配器的payload-type
属性(payloadType
属性)
@Bean
public KafkaMessageDrivenChannelAdapter<String, String>
adapter(KafkaMessageListenerContainer<String, String> container) {
KafkaMessageDrivenChannelAdapter<String, String> kafkaMessageDrivenChannelAdapter =
new KafkaMessageDrivenChannelAdapter<>(container, ListenerMode.record);
kafkaMessageDrivenChannelAdapter.setOutputChannel(received());
kafkaMessageDrivenChannelAdapter.setMessageConverter(converter());
kafkaMessageDrivenChannelAdapter.setPayloadType(Thing.class);
return kafkaMessageDrivenChannelAdapter;
}
空有效负载和日志压缩“墓碑”记录
Spring Messaging Message<?>
对象不能具有null
有效负载。当您将端点用于Apache Kafka时,null
有效负载(也称为墓碑记录)由类型为KafkaNull
的有效负载表示。有关更多信息,请参见Apache Kafka 的 Spring 文档。
Spring Integration端点的POJO方法可以使用真正的null
值而不是KafkaNull
。为此,请使用@Payload(required = false)
标记参数。以下示例显示了如何执行此操作
@ServiceActivator(inputChannel = "fromSomeKafkaInboundEndpoint")
public void in(@Header(KafkaHeaders.RECEIVED_KEY) String key,
@Payload(required = false) Customer customer) {
// customer is null if a tombstone record
...
}
从KStream
调用Spring Integration流
您可以使用MessagingTransformer
从KStream
调用集成流
@Bean
public KStream<byte[], byte[]> kStream(StreamsBuilder kStreamBuilder,
MessagingTransformer<byte[], byte[], byte[]> transformer) transformer) {
KStream<byte[], byte[]> stream = kStreamBuilder.stream(STREAMING_TOPIC1);
stream.mapValues((ValueMapper<byte[], byte[]>) String::toUpperCase)
...
.transform(() -> transformer)
.to(streamingTopic2);
stream.print(Printed.toSysOut());
return stream;
}
@Bean
@DependsOn("flow")
public MessagingTransformer<byte[], byte[], String> transformer(
MessagingFunction function) {
MessagingMessageConverter converter = new MessagingMessageConverter();
converter.setHeaderMapper(new SimpleKafkaHeaderMapper("*"));
return new MessagingTransformer<>(function, converter);
}
@Bean
public IntegrationFlow flow() {
return IntegrationFlow.from(MessagingFunction.class)
...
.get();
}
当集成流以接口开头时,创建的代理的名称为流bean的名称,后跟“.gateway”,因此此bean名称可以作为@Qualifier
使用(如果需要)。
读/处理/写场景的性能注意事项
许多应用程序从一个主题中消费数据,执行一些处理,然后写入另一个主题。在大多数情况下,如果写入
失败,应用程序会想要抛出一个异常,以便可以重试传入的请求和/或将其发送到死信主题。此功能由底层消息侦听器容器以及适当配置的错误处理程序支持。但是,为了支持这一点,我们需要阻塞侦听器线程,直到写入操作成功(或失败),以便任何异常都可以抛给容器。当消费单个记录时,这是通过在出站适配器上设置sync
属性来实现的。但是,当批量消费时,使用sync
会导致性能显著下降,因为应用程序会在发送下一条消息之前等待每个发送的结果。您也可以执行多个发送,然后之后等待这些发送的结果。这是通过向消息处理程序添加futuresChannel
来实现的。要启用此功能,请将KafkaIntegrationHeaders.FUTURE_TOKEN
添加到出站消息;然后可以使用它将Future
与特定发送的消息关联起来。这是一个关于如何使用此功能的示例
@SpringBootApplication
public class FuturesChannelApplication {
public static void main(String[] args) {
SpringApplication.run(FuturesChannelApplication.class, args);
}
@Bean
IntegrationFlow inbound(ConsumerFactory<String, String> consumerFactory, Handler handler) {
return IntegrationFlow.from(Kafka.messageDrivenChannelAdapter(consumerFactory,
ListenerMode.batch, "inTopic"))
.handle(handler)
.get();
}
@Bean
IntegrationFlow outbound(KafkaTemplate<String, String> kafkaTemplate) {
return IntegrationFlow.from(Gate.class)
.enrichHeaders(h -> h
.header(KafkaHeaders.TOPIC, "outTopic")
.headerExpression(KafkaIntegrationHeaders.FUTURE_TOKEN, "headers[id]"))
.handle(Kafka.outboundChannelAdapter(kafkaTemplate)
.futuresChannel("futures"))
.get();
}
@Bean
PollableChannel futures() {
return new QueueChannel();
}
}
@Component
@DependsOn("outbound")
class Handler {
@Autowired
Gate gate;
@Autowired
PollableChannel futures;
public void handle(List<String> input) throws Exception {
System.out.println(input);
input.forEach(str -> this.gate.send(str.toUpperCase()));
for (int i = 0; i < input.size(); i++) {
Message<?> future = this.futures.receive(10000);
((Future<?>) future.getPayload()).get(10, TimeUnit.SECONDS);
}
}
}
interface Gate {
void send(String out);
}