Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractRabbitConsumerEvent - Class in io.micronaut.rabbitmq.event
-
Abstract class for RabbitMQ consumer events.
- AbstractRabbitConsumerEvent(Object, String, String) - Constructor for class io.micronaut.rabbitmq.event.AbstractRabbitConsumerEvent
-
Default constructor.
- AbstractRabbitEvent<T> - Class in io.micronaut.rabbitmq.event
-
Abstract class for RabbitMQ events.
- AbstractRabbitEvent(T) - Constructor for class io.micronaut.rabbitmq.event.AbstractRabbitEvent
-
Default constructor.
- ack() - Method in interface io.micronaut.rabbitmq.bind.RabbitAcknowledgement
- ack(boolean) - Method in interface io.micronaut.rabbitmq.bind.RabbitAcknowledgement
-
Acknowledges this message.
- ACK - Enum constant in enum class io.micronaut.rabbitmq.bind.AcknowledgmentAction
-
The action of acknowledging a message.
- ACK - Enum constant in enum class io.micronaut.rabbitmq.reactive.BrokerResponse
- AcknowledgementBinder<T extends io.micronaut.messaging.Acknowledgement> - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of type
Acknowledgement
from theRabbitConsumerState
. - AcknowledgementBinder() - Constructor for class io.micronaut.rabbitmq.bind.AcknowledgementBinder
- AcknowledgmentAction - Enum Class in io.micronaut.rabbitmq.bind
-
Represents options for controlling the acknowledgment actions.
- addEventuallyUpListener(TemporarilyDownConnection.EventuallyUpListener) - Method in interface io.micronaut.rabbitmq.connect.recovery.TemporarilyDownConnection
- AddressTypeConverter - Class in io.micronaut.rabbitmq.connect
-
Converts a CharSequence to an
Address
. - AddressTypeConverter() - Constructor for class io.micronaut.rabbitmq.connect.AddressTypeConverter
- argumentType() - Method in class io.micronaut.rabbitmq.bind.AcknowledgementBinder
- argumentType() - Method in class io.micronaut.rabbitmq.bind.RabbitAcknowledgementBinder
- argumentType() - Method in class io.micronaut.rabbitmq.bind.RabbitBasicPropertiesBinder
- argumentType() - Method in class io.micronaut.rabbitmq.bind.RabbitChannelBinder
- argumentType() - Method in class io.micronaut.rabbitmq.bind.RabbitEnvelopeBinder
- autoAcknowledgment() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
B
- bind(ArgumentConversionContext<BasicProperties>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitBasicPropertiesBinder
- bind(ArgumentConversionContext<Channel>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitChannelBinder
- bind(ArgumentConversionContext<Envelope>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitEnvelopeBinder
- bind(ArgumentConversionContext<Object>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitBodyBinder
- bind(ArgumentConversionContext<Object>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitDefaultBinder
-
Checks if the argument name matches one of the
BasicProperties
. - bind(ArgumentConversionContext<Object>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitHeaderBinder
- bind(ArgumentConversionContext<Object>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitHeadersBinder
- bind(ArgumentConversionContext<Object>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.RabbitPropertyBinder
- bind(ArgumentConversionContext<T>, RabbitConsumerState) - Method in class io.micronaut.rabbitmq.bind.AcknowledgementBinder
- Binding - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Used to specify which binding (routing key) messages should be sent to.
- BrokerResponse - Enum Class in io.micronaut.rabbitmq.reactive
-
An enumeration to represent the three possible states of response from a broker.
C
- ChannelInitializer - Class in io.micronaut.rabbitmq.connect
-
A base class to extend from to do initialization work with a channel before any consumers or producers are created.
- ChannelInitializer() - Constructor for class io.micronaut.rabbitmq.connect.ChannelInitializer
- ChannelPool - Interface in io.micronaut.rabbitmq.connect
-
A pool of
Channel
s to allow for channels to be shared across threads but not at the same time. - ChannelPoolConfiguration() - Constructor for class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.ChannelPoolConfiguration
- check() - Method in interface io.micronaut.rabbitmq.connect.recovery.TemporarilyDownConnection
- close() - Method in class io.micronaut.rabbitmq.bind.RabbitMessageCloseable
- close() - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
- close() - Method in class io.micronaut.rabbitmq.intercept.RabbitMQConsumerAdvice
- ClusterRabbitConnectionFactoryConfig - Class in io.micronaut.rabbitmq.connect
-
Allows configuration of multiple RabbitMQ connections.
- ClusterRabbitConnectionFactoryConfig(String) - Constructor for class io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig
-
Default constructor.
- ClusterRabbitConnectionFactoryConfig.DefaultChannelPoolConfiguration - Class in io.micronaut.rabbitmq.connect
- ClusterRabbitConnectionFactoryConfig.DefaultRpcConfiguration - Class in io.micronaut.rabbitmq.connect
- connection() - Element in annotation interface io.micronaut.rabbitmq.annotation.Binding
- connection() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
- connection() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitClient
- connection() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitConnection
- connection() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitListener
- convert(CharSequence, Class<Address>, ConversionContext) - Method in class io.micronaut.rabbitmq.connect.AddressTypeConverter
- createChannel() - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
-
Creates a channel.
- createConsumer(Channel, RabbitPublishState, String, MonoSink<RabbitConsumerState>) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Listens for ack/nack from the broker.
- createListener(Channel, MonoSink<Object>, RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Listens for ack/nack from the broker.
D
- DEFAULT_CONNECTION - Static variable in annotation interface io.micronaut.rabbitmq.annotation.RabbitConnection
- DEFAULT_NAME - Static variable in class io.micronaut.rabbitmq.connect.SingleRabbitConnectionFactoryConfig
- DEFAULT_RECOVERY_DELAY - Static variable in interface io.micronaut.rabbitmq.connect.ChannelPool
-
The default delay to apply for recovery channel getter.
- DEFAULT_TIMEOUT_SECONDS - Static variable in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.RpcConfiguration
-
The default timeout before cancelling an RPC call.
- DefaultChannelPool - Class in io.micronaut.rabbitmq.connect
-
Default implementation of
ChannelPool
. - DefaultChannelPool(String, Connection, RabbitConnectionFactoryConfig) - Constructor for class io.micronaut.rabbitmq.connect.DefaultChannelPool
-
Default constructor.
- DefaultChannelPoolConfiguration() - Constructor for class io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig.DefaultChannelPoolConfiguration
- DefaultChannelPoolConfiguration() - Constructor for class io.micronaut.rabbitmq.connect.SingleRabbitConnectionFactoryConfig.DefaultChannelPoolConfiguration
- DefaultConsumer - Interface in io.micronaut.rabbitmq.intercept
-
A default
Consumer
that delegates cancelled or shutdown with a single methodDefaultConsumer.handleTerminate(String)
. - DefaultRabbitListenerExceptionHandler - Class in io.micronaut.rabbitmq.exception
-
The default ExceptionHandler used when a
RabbitListener
fails to process a RabbitMQ message. - DefaultRabbitListenerExceptionHandler() - Constructor for class io.micronaut.rabbitmq.exception.DefaultRabbitListenerExceptionHandler
- DefaultRabbitMessageSerDesRegistry - Class in io.micronaut.rabbitmq.serdes
-
Default implementation of
RabbitMessageSerDesRegistry
. - DefaultRabbitMessageSerDesRegistry(RabbitMessageSerDes<?>...) - Constructor for class io.micronaut.rabbitmq.serdes.DefaultRabbitMessageSerDesRegistry
-
Default constructor.
- DefaultRpcConfiguration() - Constructor for class io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig.DefaultRpcConfiguration
- DefaultRpcConfiguration() - Constructor for class io.micronaut.rabbitmq.connect.SingleRabbitConnectionFactoryConfig.DefaultRpcConfiguration
- deserialize(RabbitConsumerState, Argument<Object>) - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- deserialize(RabbitConsumerState, Argument<Object>) - Method in class io.micronaut.rabbitmq.serdes.JsonRabbitMessageSerDes
- deserialize(RabbitConsumerState, Argument<T>) - Method in interface io.micronaut.rabbitmq.serdes.RabbitMessageSerDes
-
Deserializes the message into the requested type.
E
- ERROR_MESSAGE - Static variable in interface io.micronaut.rabbitmq.connect.recovery.TemporarilyDownException
- exclusive() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
- executor() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
- executor() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitConnection
- executor() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitListener
F
- findArgumentBinder(Argument<T>) - Method in class io.micronaut.rabbitmq.bind.RabbitBinderRegistry
- findSerdes(Argument<T>) - Method in class io.micronaut.rabbitmq.serdes.DefaultRabbitMessageSerDesRegistry
- findSerdes(Argument<T>) - Method in interface io.micronaut.rabbitmq.serdes.RabbitMessageSerDesRegistry
-
Returns the serdes that supports the given type.
- findSerDes(Argument<?>) - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
-
Finds the correct serDes based on the type.
G
- get(CharSequence, ArgumentConversionContext<T>) - Method in class io.micronaut.rabbitmq.bind.RabbitHeaderConvertibleValues
- getAddresses() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- getAnnotationType() - Method in class io.micronaut.rabbitmq.bind.RabbitBodyBinder
- getAnnotationType() - Method in class io.micronaut.rabbitmq.bind.RabbitHeaderBinder
- getAnnotationType() - Method in class io.micronaut.rabbitmq.bind.RabbitHeadersBinder
- getAnnotationType() - Method in class io.micronaut.rabbitmq.bind.RabbitPropertyBinder
- getAppId() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getBody() - Method in class io.micronaut.rabbitmq.bind.RabbitConsumerState
- getBody() - Method in class io.micronaut.rabbitmq.reactive.RabbitPublishState
- getBooleanSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getByteArraySerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getByteBufferSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getChannel() - Method in class io.micronaut.rabbitmq.bind.RabbitConsumerState
-
This channel is being used exclusively by the consumer that consumed this message.
- getChannel() - Method in interface io.micronaut.rabbitmq.connect.ChannelPool
-
Retrieves a channel from the pool.
- getChannel() - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
- getChannel() - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Creates a
Mono
from a channel, emitting an error if the channel could not be retrieved. - getChannelPool() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- getChannelWithRecoveringDelay(int) - Method in interface io.micronaut.rabbitmq.connect.ChannelPool
-
Retrieves a channel from the pool after blocking the thread for a delay period defined by the
RecoveryDelayHandler
of the connection for this pool. - getChannelWithRecoveringDelay(int) - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
- getClusterId() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getConfirmTimeout() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- getConnection() - Method in interface io.micronaut.rabbitmq.connect.recovery.TemporarilyDownException
-
Returns the temporarily down connection that caused this exception.
- getConsumerExecutor() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- getContentEncoding() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getContentType() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getConversionErrors() - Method in class io.micronaut.rabbitmq.bind.RabbitHeaderConvertibleValues
- getCorrelationId() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getDeliveryMode() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getDetails(Connection) - Method in class io.micronaut.rabbitmq.health.RabbitMQHealthIndicator
- getDoubleSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getEnvelope() - Method in class io.micronaut.rabbitmq.bind.RabbitConsumerState
- getExchange() - Method in class io.micronaut.rabbitmq.reactive.RabbitPublishState
- getExpiration() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getFailures() - Method in exception io.micronaut.rabbitmq.exception.RabbitClientException
- getFloatSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getHeaders() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getHealthInformation() - Method in class io.micronaut.rabbitmq.health.RabbitMQHealthIndicator
- getIntegerSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getListener() - Method in exception io.micronaut.rabbitmq.exception.RabbitListenerException
- getLongSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getMandatory() - Method in class io.micronaut.rabbitmq.reactive.RabbitPublishState
- getMaxIdleChannels() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.ChannelPoolConfiguration
- getMessageId() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getMessageState() - Method in exception io.micronaut.rabbitmq.exception.RabbitListenerException
- getMethod() - Method in class io.micronaut.rabbitmq.event.AbstractRabbitConsumerEvent
- getName() - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
- getName() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- getName() - Method in class io.micronaut.rabbitmq.health.RabbitMQHealthIndicator
- getOrder() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getOrder() - Method in class io.micronaut.rabbitmq.serdes.JsonRabbitMessageSerDes
- getPriority() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getProperties() - Method in class io.micronaut.rabbitmq.bind.RabbitConsumerState
- getProperties() - Method in class io.micronaut.rabbitmq.reactive.RabbitPublishState
- getQueue() - Method in class io.micronaut.rabbitmq.event.AbstractRabbitConsumerEvent
- getReplyTo() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getRoutingKey() - Method in class io.micronaut.rabbitmq.reactive.RabbitPublishState
- getRpc() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- getShortSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getSource() - Method in class io.micronaut.rabbitmq.event.AbstractRabbitEvent
- getStringSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- getTimeout() - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.RpcConfiguration
- getTimestamp() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getType() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getUserId() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
- getUUIDSerDes() - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
H
- handle(RabbitListenerException) - Method in class io.micronaut.rabbitmq.exception.DefaultRabbitListenerExceptionHandler
- handleCancel(String) - Method in interface io.micronaut.rabbitmq.intercept.DefaultConsumer
- handleCancelOk(String) - Method in interface io.micronaut.rabbitmq.intercept.DefaultConsumer
- handleConsumeOk(String) - Method in interface io.micronaut.rabbitmq.intercept.DefaultConsumer
- handleRecoverOk(String) - Method in interface io.micronaut.rabbitmq.intercept.DefaultConsumer
- handleShutdownSignal(String, ShutdownSignalException) - Method in interface io.micronaut.rabbitmq.intercept.DefaultConsumer
- handleTerminate(String) - Method in interface io.micronaut.rabbitmq.intercept.DefaultConsumer
-
Called when a consumer is cancelled or shut down.
I
- initialize(Channel, String) - Method in class io.micronaut.rabbitmq.connect.ChannelInitializer
-
Do any work with a channel.
- initializePublish(Channel) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Initializes the channel to allow publisher acknowledgements.
- intercept(MethodInvocationContext<Object, Object>) - Method in class io.micronaut.rabbitmq.intercept.RabbitMQIntroductionAdvice
- io.micronaut.rabbitmq.annotation - package io.micronaut.rabbitmq.annotation
-
Annotations for creating RabbitMQ consumers and producers.
- io.micronaut.rabbitmq.bind - package io.micronaut.rabbitmq.bind
-
Classes for binding RabbitMQ messages to consumer methods.
- io.micronaut.rabbitmq.connect - package io.micronaut.rabbitmq.connect
-
Classes handling the connection RabbitMQ.
- io.micronaut.rabbitmq.connect.recovery - package io.micronaut.rabbitmq.connect.recovery
- io.micronaut.rabbitmq.event - package io.micronaut.rabbitmq.event
- io.micronaut.rabbitmq.exception - package io.micronaut.rabbitmq.exception
-
RabbitMQ specific exceptions.
- io.micronaut.rabbitmq.executor - package io.micronaut.rabbitmq.executor
-
Classes related to configuring the thread pool to run RabbitMQ consumers.
- io.micronaut.rabbitmq.health - package io.micronaut.rabbitmq.health
-
Classes related to performing health checks for RabbitMQ.
- io.micronaut.rabbitmq.intercept - package io.micronaut.rabbitmq.intercept
-
Contains the implementations of the
Around
advices for RabbitMQ consumer and producer methods. - io.micronaut.rabbitmq.metrics - package io.micronaut.rabbitmq.metrics
-
Contains classes specific to capturing RabbitMQ metrics.
- io.micronaut.rabbitmq.reactive - package io.micronaut.rabbitmq.reactive
-
Contains classes specific to converting the RabbitMQ java client API to a reactive API.
- io.micronaut.rabbitmq.serdes - package io.micronaut.rabbitmq.serdes
-
Classes for serializing and deserializing RabbitMQ message bodies.
- isStillDown() - Method in interface io.micronaut.rabbitmq.connect.recovery.TemporarilyDownConnection
- isTopologyRecoveryEnabled() - Method in interface io.micronaut.rabbitmq.connect.ChannelPool
-
Returns whether
topology recovery
is enabled for the connection of this pool. - isTopologyRecoveryEnabled() - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
J
- JavaLangRabbitMessageSerDes - Class in io.micronaut.rabbitmq.serdes
-
Serializes and deserializes standard Java types.
- JavaLangRabbitMessageSerDes() - Constructor for class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
-
Default constructor.
- javaSerDes - Variable in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- JsonRabbitMessageSerDes - Class in io.micronaut.rabbitmq.serdes
-
Serializes and deserializes objects as JSON using Jackson.
- JsonRabbitMessageSerDes(JsonMapper) - Constructor for class io.micronaut.rabbitmq.serdes.JsonRabbitMessageSerDes
-
Default constructor.
M
- Mandatory - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Used to specify how the server should react if the message cannot be routed to a queue.
- MutableBasicProperties - Class in io.micronaut.rabbitmq.intercept
-
A class that stores the basic properties in a mutable state.
- MutableBasicProperties() - Constructor for class io.micronaut.rabbitmq.intercept.MutableBasicProperties
N
- nack() - Method in interface io.micronaut.rabbitmq.bind.RabbitAcknowledgement
- nack(boolean, boolean) - Method in interface io.micronaut.rabbitmq.bind.RabbitAcknowledgement
-
Rejects this message.
- NACK - Enum constant in enum class io.micronaut.rabbitmq.bind.AcknowledgmentAction
-
The action of rejecting a message.
- NACK - Enum constant in enum class io.micronaut.rabbitmq.reactive.BrokerResponse
- name() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitProperty
-
Never used if applied to a parameter.
- names() - Method in class io.micronaut.rabbitmq.bind.RabbitHeaderConvertibleValues
- newConnection(RabbitConnectionFactoryConfig, ExecutorService) - Method in class io.micronaut.rabbitmq.connect.recovery.TemporarilyDownConnectionManager
-
Creates a new temporarily down RabbitMQ connection.
- NONE - Enum constant in enum class io.micronaut.rabbitmq.bind.AcknowledgmentAction
-
The acknowledgment action is going to be skipped.
- NONE - Enum constant in enum class io.micronaut.rabbitmq.reactive.BrokerResponse
- numberOfConsumers() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
- numberOfConsumersValue() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
O
- onConnectionInitialized(TemporarilyDownConnection) - Method in interface io.micronaut.rabbitmq.connect.recovery.TemporarilyDownConnection.EventuallyUpListener
-
Reacts to a connection that is eventually up.
- onCreated(BeanCreatedEvent<ConnectionFactory>) - Method in class io.micronaut.rabbitmq.metrics.RabbitMetricsInterceptor
- onCreated(BeanCreatedEvent<ChannelPool>) - Method in class io.micronaut.rabbitmq.connect.ChannelInitializer
- onPreDestroy(BeanPreDestroyEvent<ExecutorService>) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactory
-
Closes active connections associated with the
ExecutorService
prior to its removal. - ORDER - Static variable in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
-
The order of this serDes.
- ORDER - Static variable in class io.micronaut.rabbitmq.serdes.JsonRabbitMessageSerDes
-
The order of this serDes.
P
- prefetch() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
- PREFIX - Static variable in class io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig
- process(BeanDefinition<?>, ExecutableMethod<?, ?>) - Method in class io.micronaut.rabbitmq.intercept.RabbitMQConsumerAdvice
- publish(RabbitPublishState) - Method in interface io.micronaut.rabbitmq.reactive.ReactivePublisher
-
Publish the message with the provided arguments and return a reactive type that completes successfully when the message is published.
- publish(RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
- publishAndConfirm(RabbitPublishState) - Method in interface io.micronaut.rabbitmq.reactive.ReactivePublisher
-
Publish the message with the provided arguments and return a reactive type that completes successfully when the broker acknowledged the message.
- publishAndConfirm(RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
- publishAndReply(RabbitPublishState) - Method in interface io.micronaut.rabbitmq.reactive.ReactivePublisher
-
Publish the message with the provided arguments and return a reactive type that completes successfully when the reply is received from the reply to queue.
- publishAndReply(RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
- publishInternal(Channel, RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Publishes the message to the channel.
- publishInternalNoConfirm(Channel, RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Publishes the message to the channel.
- publishRpcInternal(Channel, RabbitPublishState) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Publishes the message to the channel.
Q
- Queue - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Used to specify which queue messages should be consumed from.
R
- RabbitAcknowledgement - Interface in io.micronaut.rabbitmq.bind
-
A contract for acknowledging or rejecting RabbitMQ messages.
- RabbitAcknowledgementBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of type
RabbitAcknowledgement
from theRabbitConsumerState
. - RabbitAcknowledgementBinder() - Constructor for class io.micronaut.rabbitmq.bind.RabbitAcknowledgementBinder
- RabbitAnnotatedArgumentBinder<A extends Annotation> - Interface in io.micronaut.rabbitmq.bind
-
An interface for RabbitMQ argument binding based on an annotation.
- RabbitArgumentBinder<T> - Interface in io.micronaut.rabbitmq.bind
-
An interface for RabbitMQ argument binding.
- RabbitBasicPropertiesBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of type
BasicProperties
from theRabbitConsumerState
. - RabbitBasicPropertiesBinder() - Constructor for class io.micronaut.rabbitmq.bind.RabbitBasicPropertiesBinder
- RabbitBinderRegistry - Class in io.micronaut.rabbitmq.bind
-
Used to determine which
RabbitArgumentBinder
to use for any given argument. - RabbitBinderRegistry(RabbitDefaultBinder, RabbitArgumentBinder...) - Constructor for class io.micronaut.rabbitmq.bind.RabbitBinderRegistry
-
Default constructor.
- RabbitBodyBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of with the
MessageBody
annotation from theRabbitConsumerState
. - RabbitBodyBinder(RabbitMessageSerDesRegistry) - Constructor for class io.micronaut.rabbitmq.bind.RabbitBodyBinder
-
Default constructor.
- RabbitChannelBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of type
Channel
from theRabbitConsumerState
. - RabbitChannelBinder() - Constructor for class io.micronaut.rabbitmq.bind.RabbitChannelBinder
- RabbitClient - Annotation Interface in io.micronaut.rabbitmq.annotation
-
An introduction advice that automatically implements interfaces and abstract classes and publishes RabbitMQ messages.
- RabbitClientException - Exception in io.micronaut.rabbitmq.exception
-
Exception thrown when an error occurs publishing a RabbitMQ message.
- RabbitClientException(String) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitClientException
-
Creates a new exception.
- RabbitClientException(String, Throwable) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitClientException
-
Creates a new exception.
- RabbitClientException(String, Throwable, List<RabbitPublishState>) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitClientException
-
Creates a new exception.
- RabbitClientException(String, List<RabbitPublishState>) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitClientException
-
Creates a new exception.
- RabbitConnection - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Stores options surrounding a RabbitMQ connection.
- RabbitConnectionFactory - Class in io.micronaut.rabbitmq.connect
-
A factory for creating a connection to RabbitMQ.
- RabbitConnectionFactory() - Constructor for class io.micronaut.rabbitmq.connect.RabbitConnectionFactory
- RabbitConnectionFactoryConfig - Class in io.micronaut.rabbitmq.connect
-
Base class for RabbitMQ to be configured.
- RabbitConnectionFactoryConfig(String) - Constructor for class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
-
Default constructor.
- RabbitConnectionFactoryConfig.ChannelPoolConfiguration - Class in io.micronaut.rabbitmq.connect
-
Configuration for the channel pool.
- RabbitConnectionFactoryConfig.RpcConfiguration - Class in io.micronaut.rabbitmq.connect
-
Configuration for RPC.
- RabbitConsumerExecutorFactory - Class in io.micronaut.rabbitmq.executor
-
Configures a
ScheduledExecutorService
for runningRabbitListener
instances. - RabbitConsumerExecutorFactory() - Constructor for class io.micronaut.rabbitmq.executor.RabbitConsumerExecutorFactory
- RabbitConsumerStarted - Class in io.micronaut.rabbitmq.event
-
An event fired after a
RabbitListener
subscribes to a queue. - RabbitConsumerStarted(Object, String, String) - Constructor for class io.micronaut.rabbitmq.event.RabbitConsumerStarted
-
Default constructor.
- RabbitConsumerStarting - Class in io.micronaut.rabbitmq.event
-
An event fired before a RabbitMQ consumer subscribes to a queue.
- RabbitConsumerStarting(Object, String, String) - Constructor for class io.micronaut.rabbitmq.event.RabbitConsumerStarting
-
Default constructor.
- RabbitConsumerState - Class in io.micronaut.rabbitmq.bind
-
Stores the state of a RabbitMQ message to be consumed.
- RabbitConsumerState(Envelope, AMQP.BasicProperties, byte[], Channel) - Constructor for class io.micronaut.rabbitmq.bind.RabbitConsumerState
-
Default constructor.
- RabbitDefaultBinder - Class in io.micronaut.rabbitmq.bind
-
The default binder for binding an argument from the
RabbitConsumerState
that is used if no other binder supports the argument. - RabbitDefaultBinder(RabbitPropertyBinder, RabbitBodyBinder) - Constructor for class io.micronaut.rabbitmq.bind.RabbitDefaultBinder
-
Default constructor.
- RabbitEnvelopeBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of type
Envelope
from theRabbitConsumerState
. - RabbitEnvelopeBinder() - Constructor for class io.micronaut.rabbitmq.bind.RabbitEnvelopeBinder
- RabbitHeaderBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of with the
MessageHeader
annotation from theRabbitConsumerState
. - RabbitHeaderBinder(ConversionService) - Constructor for class io.micronaut.rabbitmq.bind.RabbitHeaderBinder
-
Default constructor.
- RabbitHeaderConvertibleValues - Class in io.micronaut.rabbitmq.bind
-
Converts RabbitMQ header values to the requested type.
- RabbitHeaderConvertibleValues(Map<String, Object>, ConversionService) - Constructor for class io.micronaut.rabbitmq.bind.RabbitHeaderConvertibleValues
-
Default constructor.
- RabbitHeaders - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Denotes a
Map
argument that should be used as a source of message headers. - RabbitHeadersBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of with the
RabbitHeaders
annotation from theRabbitConsumerState
. - RabbitHeadersBinder(ConversionService) - Constructor for class io.micronaut.rabbitmq.bind.RabbitHeadersBinder
-
Default constructor.
- RabbitListener - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Class level annotation to indicate that a bean will be consumers of messages from RabbitMQ.
- RabbitListenerException - Exception in io.micronaut.rabbitmq.exception
-
Exception thrown when an error occurs processing a RabbitMQ message via a
RabbitListener
. - RabbitListenerException(String, Object, RabbitConsumerState) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitListenerException
-
Creates a new exception.
- RabbitListenerException(String, Throwable, Object, RabbitConsumerState) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitListenerException
-
Creates a new exception.
- RabbitListenerException(Throwable, Object, RabbitConsumerState) - Constructor for exception io.micronaut.rabbitmq.exception.RabbitListenerException
-
Creates a new exception.
- RabbitListenerExceptionHandler - Interface in io.micronaut.rabbitmq.exception
-
Interface that
RabbitListener
beans can implement to handle exceptions. - RabbitMessageCloseable - Class in io.micronaut.rabbitmq.bind
-
Responsible for acknowledging or rejecting a message.
- RabbitMessageCloseable(RabbitConsumerState, boolean, boolean) - Constructor for class io.micronaut.rabbitmq.bind.RabbitMessageCloseable
-
Default constructor.
- RabbitMessageSerDes<T> - Interface in io.micronaut.rabbitmq.serdes
-
Responsible for serializing and deserializing RabbitMQ message bodies.
- RabbitMessageSerDesRegistry - Interface in io.micronaut.rabbitmq.serdes
-
A registry of
RabbitMessageSerDes
instances. - RabbitMetricsInterceptor - Class in io.micronaut.rabbitmq.metrics
-
Interceptor of the connection factory to set the metrics collector.
- RabbitMetricsInterceptor(BeanProvider<MeterRegistry>, String, Map<String, String>) - Constructor for class io.micronaut.rabbitmq.metrics.RabbitMetricsInterceptor
-
Default constructor.
- RabbitMQConsumerAdvice - Class in io.micronaut.rabbitmq.intercept
-
An
ExecutableMethodProcessor
that will process all beans annotated withRabbitListener
and create and subscribe the relevant methods as consumers to RabbitMQ queues. - RabbitMQConsumerAdvice(BeanContext, ApplicationEventPublisher<RabbitConsumerStarting>, ApplicationEventPublisher<RabbitConsumerStarted>, RabbitBinderRegistry, RabbitListenerExceptionHandler, RabbitMessageSerDesRegistry, ConversionService, List<ChannelPool>) - Constructor for class io.micronaut.rabbitmq.intercept.RabbitMQConsumerAdvice
-
Default constructor.
- RabbitMQConsumerAdvice(BeanContext, RabbitBinderRegistry, RabbitListenerExceptionHandler, RabbitMessageSerDesRegistry, ConversionService, List<ChannelPool>) - Constructor for class io.micronaut.rabbitmq.intercept.RabbitMQConsumerAdvice
-
Deprecated, for removal: This API element is subject to removal in a future version.
- RabbitMQHealthIndicator - Class in io.micronaut.rabbitmq.health
-
A
HealthIndicator
for RabbitMQ. - RabbitMQHealthIndicator(Connection) - Constructor for class io.micronaut.rabbitmq.health.RabbitMQHealthIndicator
-
Default constructor.
- RabbitMQHealthIndicator(List<Connection>) - Constructor for class io.micronaut.rabbitmq.health.RabbitMQHealthIndicator
-
Default constructor.
- RabbitMQIntroductionAdvice - Class in io.micronaut.rabbitmq.intercept
-
Implementation of the
RabbitClient
advice annotation. - RabbitMQIntroductionAdvice(BeanContext, ConversionService, RabbitMessageSerDesRegistry, ExecutorService) - Constructor for class io.micronaut.rabbitmq.intercept.RabbitMQIntroductionAdvice
-
Default constructor.
- RabbitProperties - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Annotation to collect a set of properties.
- RabbitProperty - Annotation Interface in io.micronaut.rabbitmq.annotation
-
Used to set properties while publishing or bind to properties while consuming.
- RabbitPropertyBinder - Class in io.micronaut.rabbitmq.bind
-
Binds an argument of with the
RabbitProperty
annotation from theRabbitConsumerState
. - RabbitPropertyBinder(ConversionService) - Constructor for class io.micronaut.rabbitmq.bind.RabbitPropertyBinder
-
Default constructor.
- RabbitPublishState - Class in io.micronaut.rabbitmq.reactive
-
Stores the state of a RabbitMQ message to be published.
- RabbitPublishState(String, String, boolean, AMQP.BasicProperties, byte[]) - Constructor for class io.micronaut.rabbitmq.reactive.RabbitPublishState
-
Default constructor.
- RabbitPublishState(String, String, AMQP.BasicProperties, byte[]) - Constructor for class io.micronaut.rabbitmq.reactive.RabbitPublishState
-
Deprecated, for removal: This API element is subject to removal in a future version.
- RabbitTypeArgumentBinder<T> - Interface in io.micronaut.rabbitmq.bind
-
An interface for RabbitMQ argument binding based on argument type.
- ReactivePublisher - Interface in io.micronaut.rabbitmq.reactive
-
A generic contract for publishing RabbitMQ messages reactively.
- ReactorReactivePublisher - Class in io.micronaut.rabbitmq.reactive
-
A reactive publisher implementation that uses a single channel per publish operation and returns a Reactor
Mono
. - ReactorReactivePublisher(ChannelPool, RabbitConnectionFactoryConfig) - Constructor for class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Default constructor.
- reQueue() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
-
Only applies to consumer methods that do not inject an
Acknowledgement
instance. - returnChannel(Channel) - Method in interface io.micronaut.rabbitmq.connect.ChannelPool
-
Returns a channel to the pool.
- returnChannel(Channel) - Method in class io.micronaut.rabbitmq.connect.DefaultChannelPool
- returnChannel(Channel) - Method in class io.micronaut.rabbitmq.reactive.ReactorReactivePublisher
-
Removes confirm listeners from the channel and returns the channel to the pool.
- RpcConfiguration() - Constructor for class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.RpcConfiguration
S
- serialize(Object, MutableBasicProperties) - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- serialize(Object, MutableBasicProperties) - Method in class io.micronaut.rabbitmq.serdes.JsonRabbitMessageSerDes
- serialize(T, MutableBasicProperties) - Method in interface io.micronaut.rabbitmq.serdes.RabbitMessageSerDes
-
Serializes the data into a byte[] to be published to RabbitMQ.
- setAddresses(List<Address>) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
-
Sets the addresses to be passed to
ConnectionFactory.newConnection(List)
. - setAppId(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the app id.
- setChannelPool(ClusterRabbitConnectionFactoryConfig.DefaultChannelPoolConfiguration) - Method in class io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig
-
Sets the channel pool configuration.
- setChannelPool(RabbitConnectionFactoryConfig.ChannelPoolConfiguration) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
-
Sets the channel pool configuration.
- setChannelPool(SingleRabbitConnectionFactoryConfig.DefaultChannelPoolConfiguration) - Method in class io.micronaut.rabbitmq.connect.SingleRabbitConnectionFactoryConfig
-
Sets the channel pool configuration.
- setClusterId(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the cluster id.
- setConfirmTimeout(Duration) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
- setConsumerExecutor(String) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
-
Sets the name of which executor service consumers should be executed on.
- setContentEncoding(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the content encoding.
- setContentType(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the content type.
- setCorrelationId(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the correlation id.
- setDeliveryMode(Integer) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the delivery mode.
- setExpiration(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the expiration.
- setHeaders(Map<String, Object>) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the headers.
- setMaxIdleChannels(Integer) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.ChannelPoolConfiguration
-
Sets the maximum number of idle channels that will be kept open.
- setMessageId(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the message id.
- setPriority(Integer) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the priority.
- setReplyTo(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the reply to.
- setRpc(ClusterRabbitConnectionFactoryConfig.DefaultRpcConfiguration) - Method in class io.micronaut.rabbitmq.connect.ClusterRabbitConnectionFactoryConfig
-
Sets the RPC configuration.
- setRpc(RabbitConnectionFactoryConfig.RpcConfiguration) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig
-
Sets the RPC configuration.
- setRpc(SingleRabbitConnectionFactoryConfig.DefaultRpcConfiguration) - Method in class io.micronaut.rabbitmq.connect.SingleRabbitConnectionFactoryConfig
-
Sets the RPC configuration.
- setTimeout(Duration) - Method in class io.micronaut.rabbitmq.connect.RabbitConnectionFactoryConfig.RpcConfiguration
-
Sets the timeout duration before cancelling an RPC call.
- setTimestamp(Date) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the timestamp.
- setType(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the type.
- setUserId(String) - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Sets the user id.
- SingleRabbitConnectionFactoryConfig - Class in io.micronaut.rabbitmq.connect
-
The default RabbitMQ configuration class.
- SingleRabbitConnectionFactoryConfig() - Constructor for class io.micronaut.rabbitmq.connect.SingleRabbitConnectionFactoryConfig
-
Default constructor.
- SingleRabbitConnectionFactoryConfig.DefaultChannelPoolConfiguration - Class in io.micronaut.rabbitmq.connect
- SingleRabbitConnectionFactoryConfig.DefaultRpcConfiguration - Class in io.micronaut.rabbitmq.connect
- supports(ArgumentConversionContext<Object>) - Method in class io.micronaut.rabbitmq.bind.RabbitPropertyBinder
- supports(Argument<Object>) - Method in class io.micronaut.rabbitmq.serdes.JavaLangRabbitMessageSerDes
- supports(Argument<Object>) - Method in class io.micronaut.rabbitmq.serdes.JsonRabbitMessageSerDes
- supports(Argument<T>) - Method in interface io.micronaut.rabbitmq.serdes.RabbitMessageSerDes
-
Determines if this serdes supports the given type.
T
- TemporarilyDownConnection - Interface in io.micronaut.rabbitmq.connect.recovery
-
Represents a connection to RabbitMQ that is temporarily down.
- TemporarilyDownConnection.EventuallyUpListener - Interface in io.micronaut.rabbitmq.connect.recovery
-
Callback interface to perform any action when the connection is eventually up.
- TemporarilyDownConnectionManager - Class in io.micronaut.rabbitmq.connect.recovery
-
Creates temporarily down RabbitMQ connections and checks periodically if they are eventually up.
- TemporarilyDownConnectionManager() - Constructor for class io.micronaut.rabbitmq.connect.recovery.TemporarilyDownConnectionManager
- TemporarilyDownException - Interface in io.micronaut.rabbitmq.connect.recovery
-
Indicates that the connection is still down.
- toBasicProperties() - Method in class io.micronaut.rabbitmq.intercept.MutableBasicProperties
-
Converts the mutable properties to the RabbitMQ properties.
- type() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitProperty
-
Only to be used when defining consumer arguments to convert the value to the required type by RabbitMQ.
V
- value() - Element in annotation interface io.micronaut.rabbitmq.annotation.Binding
-
Should always be supplied when the annotation is applied to a method.
- value() - Element in annotation interface io.micronaut.rabbitmq.annotation.Mandatory
- value() - Element in annotation interface io.micronaut.rabbitmq.annotation.Queue
- value() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitClient
- value() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitProperties
-
This allows you to have multiple @RabbitProperty annotations set at the class level with Java and Groovy.
- value() - Element in annotation interface io.micronaut.rabbitmq.annotation.RabbitProperty
-
If used as a bound parameter, this is the property name.
- valueOf(String) - Static method in enum class io.micronaut.rabbitmq.bind.AcknowledgmentAction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class io.micronaut.rabbitmq.reactive.BrokerResponse
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class io.micronaut.rabbitmq.bind.AcknowledgmentAction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class io.micronaut.rabbitmq.bind.RabbitHeaderConvertibleValues
- values() - Static method in enum class io.micronaut.rabbitmq.reactive.BrokerResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
W
- withAcknowledge(Boolean) - Method in class io.micronaut.rabbitmq.bind.RabbitMessageCloseable
-
Deprecated.as of 3.4.0
- withAcknowledgmentAction(AcknowledgmentAction) - Method in class io.micronaut.rabbitmq.bind.RabbitMessageCloseable
-
Builder style sets whether the message acknowledgment action should be addressed and message should be acknowledged or rejected, or otherwise should acknowledgment action be skipped.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
RabbitMQConsumerAdvice(BeanContext, ApplicationEventPublisher, ApplicationEventPublisher, RabbitBinderRegistry, RabbitListenerExceptionHandler, RabbitMessageSerDesRegistry, ConversionService, List)
}