Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
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
KafkaAckCallbackFactory
record 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
ErrorMessagePublisher
that can be used in aCommonErrorHandler
for 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
MessagingGatewaySpec
implementation for theKafkaInboundGateway
. - KafkaInboundGatewaySpec.KafkaInboundGatewayListenerContainerSpec<K,
V, R> - Class in org.springframework.integration.kafka.dsl -
A
ConcurrentMessageListenerContainer
configurationKafkaInboundGatewaySpec
extension. - 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
MessageProducerSpec
implementation for theKafkaMessageDrivenChannelAdapter
. - KafkaMessageDrivenChannelAdapterSpec.KafkaMessageDrivenChannelAdapterListenerContainerSpec<K,
V> - Class in org.springframework.integration.kafka.dsl -
A
ConcurrentMessageListenerContainer
configurationKafkaMessageDrivenChannelAdapterSpec
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 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
MessageHandlerSpec
implementation for theKafkaProducerMessageHandler
as a gateway. - KafkaOutboundGatewaySpec.KafkaGatewayMessageHandlerTemplateSpec<K,
V, R> - Class in org.springframework.integration.kafka.dsl -
A
KafkaTemplate
-basedKafkaProducerMessageHandlerSpec
extension. - KafkaOutboundGatewaySpec.ReplyingKafkaTemplateSpec<K,
V, R> - Class in org.springframework.integration.kafka.dsl -
An
IntegrationComponentSpec
implementation 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
ReplyingKafkaTemplate
it 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
ProducerRecord
from aMessage
and/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
MessageHandlerSpec
implementation for theKafkaProducerMessageHandler
. - KafkaProducerMessageHandlerSpec.KafkaProducerMessageHandlerTemplateSpec<K,
V> - Class in org.springframework.integration.kafka.dsl -
A
KafkaTemplate
-basedKafkaProducerMessageHandlerSpec
extension. - 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
ErrorMessage
when 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
IntegrationComponentSpec
implementation for theKafkaTemplate
. - key - Variable in class org.springframework.integration.hazelcast.message.EntryEventMessagePayload
-
The entry key.
- KEY - Enum constant in enum class org.springframework.integration.hazelcast.DistributedSQLIterationType
-
The
IMap.keySet()
to iterate. - KEY - Static variable in class org.springframework.integration.redis.metadata.RedisMetadataStore
- KEY - Static variable in class org.springframework.integration.redis.support.RedisHeaders
- KEY_TYPE_ID - Static variable in class org.springframework.integration.mapping.support.JsonHeaders
- KeyDirectory(Object, String) - Constructor for class org.springframework.integration.file.remote.aop.RotationPolicy.KeyDirectory
- keySet() - Method in class org.springframework.integration.expression.ExpressionEvalMap
- KOTLIN_FUNCTION_0_CLASS - Static variable in class org.springframework.integration.util.ClassUtils
-
The
kotlin.jvm.functions.Function0
class object. - KOTLIN_FUNCTION_0_INVOKE_METHOD - Static variable in class org.springframework.integration.util.ClassUtils
-
The
kotlin.jvm.functions.Function0#invoke
method object. - KOTLIN_FUNCTION_1_CLASS - Static variable in class org.springframework.integration.util.ClassUtils
-
The
kotlin.jvm.functions.Function1
class object. - KotlinScriptExecutor - Class in org.springframework.integration.scripting.jsr223
-
An
AbstractScriptExecutor
for the Kotlin scripts support. - KotlinScriptExecutor() - Constructor for class org.springframework.integration.scripting.jsr223.KotlinScriptExecutor
- KRYO - Static variable in class org.springframework.integration.codec.kryo.AbstractKryoRegistrar
- KryoClassListRegistrar - Class in org.springframework.integration.codec.kryo
-
A
KryoRegistrar
used to validateRegistration a list of Java classes. - KryoClassListRegistrar(Class<?>...) - Constructor for class org.springframework.integration.codec.kryo.KryoClassListRegistrar
- KryoClassListRegistrar(List<Class<?>>) - Constructor for class org.springframework.integration.codec.kryo.KryoClassListRegistrar
- KryoClassMapRegistrar - Class in org.springframework.integration.codec.kryo
-
A
KryoRegistrar
implementation backed by a Map used to explicitly set the registration ID for each class. - KryoClassMapRegistrar(Map<Integer, Class<?>>) - Constructor for class org.springframework.integration.codec.kryo.KryoClassMapRegistrar
- KryoRegistrar - Interface in org.springframework.integration.codec.kryo
-
Strategy interface used by
PojoCodec
to configure registrations classes consistently acrossKryo
instances. - KryoRegistrationRegistrar - Class in org.springframework.integration.codec.kryo
-
A
KryoRegistrar
implementation backed by a List ofRegistration
. - KryoRegistrationRegistrar(List<Registration>) - Constructor for class org.springframework.integration.codec.kryo.KryoRegistrationRegistrar
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form