Uses of Class
org.springframework.amqp.AmqpException
Packages that use AmqpException
Package
Description
Base package for Spring AMQP.
Provides core classes for the spring AMQP abstraction.
Provides classes related to connections.
Provides core classes for Spring Rabbit.
Provides classes for message listener containers.
Provides classes for adapting listeners.
Provides classes for listener exceptions.
Provides support classes for Spring Rabbit.
Provides classes for supporting message conversion.
Package for Spring AMQP message post processors.
Provides classes for stream producers.
- 
Uses of AmqpException in org.springframework.amqpSubclasses of AmqpException in org.springframework.amqpModifier and TypeClassDescriptionclassThrown when the connection factory has been destroyed during context close; the factory can no longer open connections.classRuntime wrapper for an authentication exception.classRuntimeException wrapper for anConnectExceptionwhich can be commonly thrown from AMQP operations if the remote process dies or there is a network issue.classEquivalent of an IllegalStateException but within the AmqpException hierarchy.classRuntimeException wrapper for anIOExceptionwhich can be commonly thrown from AMQP operations.classException for listener implementations used to indicate thebasic.rejectwill be sent withrequeue=falsein order to enable features such as DLQ.classAn exception that wraps an exception thrown by the server in a request/reply scenario.classTheAmqpExceptionthrown when some resource can't be accessed.classException thrown when some time-bound operation fails to execute in the desired time.classRuntimeException for unsupported encoding in an AMQP operation.classSpecial exception for listener implementations that want to signal that the current batch of messages should be acknowledged immediately (i.e.classThe specialAmqpExceptionto be thrown from the listener (e.g.classA "catch-all" exception type within the AmqpException hierarchy when no more specific cause is known.
- 
Uses of AmqpException in org.springframework.amqp.coreSubclasses of AmqpException in org.springframework.amqp.coreModifier and TypeClassDescriptionclassException thrown if the request message cannot be delivered when the mandatory flag is set.classAsync reply timeout.Methods in org.springframework.amqp.core that throw AmqpExceptionModifier and TypeMethodDescriptionvoidAmqpTemplate.convertAndSend(Object message) Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.voidAmqpTemplate.convertAndSend(Object message, MessagePostProcessor messagePostProcessor) Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.voidAmqpTemplate.convertAndSend(String routingKey, Object message) Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.voidAmqpTemplate.convertAndSend(String routingKey, Object message, MessagePostProcessor messagePostProcessor) Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.voidAmqpTemplate.convertAndSend(String exchange, String routingKey, Object message) Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.voidAmqpTemplate.convertAndSend(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor) Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.@Nullable ObjectAmqpTemplate.convertSendAndReceive(Object message) Basic RPC pattern with conversion.@Nullable ObjectAmqpTemplate.convertSendAndReceive(Object message, MessagePostProcessor messagePostProcessor) Basic RPC pattern with conversion.@Nullable ObjectAmqpTemplate.convertSendAndReceive(String routingKey, Object message) Basic RPC pattern with conversion.@Nullable ObjectAmqpTemplate.convertSendAndReceive(String routingKey, Object message, MessagePostProcessor messagePostProcessor) Basic RPC pattern with conversion.@Nullable ObjectAmqpTemplate.convertSendAndReceive(String exchange, String routingKey, Object message) Basic RPC pattern with conversion.@Nullable ObjectAmqpTemplate.convertSendAndReceive(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor) Basic RPC pattern with conversion.<T> @Nullable TAmqpTemplate.convertSendAndReceiveAsType(Object message, MessagePostProcessor messagePostProcessor, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TAmqpTemplate.convertSendAndReceiveAsType(Object message, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TAmqpTemplate.convertSendAndReceiveAsType(String routingKey, Object message, MessagePostProcessor messagePostProcessor, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TAmqpTemplate.convertSendAndReceiveAsType(String routingKey, Object message, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TAmqpTemplate.convertSendAndReceiveAsType(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TAmqpTemplate.convertSendAndReceiveAsType(String exchange, String routingKey, Object message, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.MessagePostProcessor.postProcessMessage(Message message) Change (or replace) the message.@Nullable MessageAmqpTemplate.receive()Receive a message if there is one from a default queue.@Nullable MessageAmqpTemplate.receive(long timeoutMillis) Receive a message from a default queue, waiting up to the specified wait time if necessary for a message to become available.@Nullable MessageReceive a message if there is one from a specific queue.@Nullable MessageReceive a message from a specific queue, waiting up to the specified wait time if necessary for a message to become available.@Nullable ObjectAmqpTemplate.receiveAndConvert()Receive a message if there is one from a default queue and convert it to a Java object.@Nullable ObjectAmqpTemplate.receiveAndConvert(long timeoutMillis) Receive a message if there is one from a default queue and convert it to a Java object.<T> @Nullable TAmqpTemplate.receiveAndConvert(long timeoutMillis, ParameterizedTypeReference<T> type) Receive a message if there is one from a default queue and convert it to a Java object.@Nullable ObjectAmqpTemplate.receiveAndConvert(String queueName) Receive a message if there is one from a specific queue and convert it to a Java object.@Nullable ObjectAmqpTemplate.receiveAndConvert(String queueName, long timeoutMillis) Receive a message if there is one from a specific queue and convert it to a Java object.<T> @Nullable TAmqpTemplate.receiveAndConvert(String queueName, long timeoutMillis, ParameterizedTypeReference<T> type) Receive a message if there is one from a specific queue and convert it to a Java object.<T> @Nullable TAmqpTemplate.receiveAndConvert(String queueName, ParameterizedTypeReference<T> type) Receive a message if there is one from a specific queue and convert it to a Java object.<T> @Nullable TAmqpTemplate.receiveAndConvert(ParameterizedTypeReference<T> type) Receive a message if there is one from a default queue and convert it to a Java object.<R,S> boolean AmqpTemplate.receiveAndReply(String queueName, ReceiveAndReplyCallback<R, S> callback) Receive a message if there is one from provided queue, invoke providedReceiveAndReplyCallbackand send reply message, if thecallbackreturns one, to thereplyToAddressfromMessagePropertiesor to default exchange and default routingKey.<R,S> boolean AmqpTemplate.receiveAndReply(String queueName, ReceiveAndReplyCallback<R, S> callback, String replyExchange, String replyRoutingKey) Receive a message if there is one from provided queue, invoke providedReceiveAndReplyCallbackand send reply message, if thecallbackreturns one, to the providedexchangeandroutingKey.<R,S> boolean AmqpTemplate.receiveAndReply(String queueName, ReceiveAndReplyCallback<R, S> callback, ReplyToAddressCallback<S> replyToAddressCallback) Receive a message if there is one from provided queue, invoke providedReceiveAndReplyCallbackand send reply message, if thecallbackreturns one, to thereplyToAddressfrom result ofReplyToAddressCallback.<R,S> boolean AmqpTemplate.receiveAndReply(ReceiveAndReplyCallback<R, S> callback) Receive a message if there is one from a default queue, invoke providedReceiveAndReplyCallbackand send reply message, if thecallbackreturns one, to thereplyToAddressfromMessagePropertiesor to default exchange and default routingKey.<R,S> boolean AmqpTemplate.receiveAndReply(ReceiveAndReplyCallback<R, S> callback, String replyExchange, String replyRoutingKey) Receive a message if there is one from default queue, invoke providedReceiveAndReplyCallbackand send reply message, if thecallbackreturns one, to the providedexchangeandroutingKey.<R,S> boolean AmqpTemplate.receiveAndReply(ReceiveAndReplyCallback<R, S> callback, ReplyToAddressCallback<S> replyToAddressCallback) Receive a message if there is one from a default queue, invoke providedReceiveAndReplyCallbackand send reply message, if thecallbackreturns one, to thereplyToAddressfrom result ofReplyToAddressCallback.voidSend a message to a specific exchange with a specific routing key.voidSend a message to a default exchange with a specific routing key.voidSend a message to a default exchange with a default routing key.@Nullable MessageAmqpTemplate.sendAndReceive(String exchange, String routingKey, Message message) Basic RPC pattern.@Nullable MessageAmqpTemplate.sendAndReceive(String routingKey, Message message) Basic RPC pattern.@Nullable MessageAmqpTemplate.sendAndReceive(Message message) Basic RPC pattern.
- 
Uses of AmqpException in org.springframework.amqp.rabbit.connectionSubclasses of AmqpException in org.springframework.amqp.rabbit.connectionModifier and TypeClassDescriptionclassRepresents a failure to commit or rollback when performing afterCompletion after the primary transaction completes.classAn exception thrown if the connection is an auto recover connection that is not currently open and is in the process of being recovered.Methods in org.springframework.amqp.rabbit.connection that throw AmqpExceptionModifier and TypeMethodDescriptionvoidConnection.close()Close this connection and all its channels with theAMQP.REPLY_SUCCESSclose code and message 'OK'.voidRabbitResourceHolder.commitAll()com.rabbitmq.client.ChannelConnection.createChannel(boolean transactional) Create a new channel, using an internally allocated channel number.AbstractRoutingConnectionFactory.createConnection()final ConnectionCachingConnectionFactory.createConnection()ConnectionFactory.createConnection()LocalizedQueueConnectionFactory.createConnection()PooledChannelConnectionFactory.createConnection()ThreadChannelConnectionFactory.createConnection()
- 
Uses of AmqpException in org.springframework.amqp.rabbit.coreSubclasses of AmqpException in org.springframework.amqp.rabbit.coreModifier and TypeClassDescriptionclassAn exception thrown when a negative acknowledgement received after publishing a message.classThrown when a blocking receive operation is performed but the consumeOk was not received before the receive timeout.Methods in org.springframework.amqp.rabbit.core that throw AmqpExceptionModifier and TypeMethodDescriptionvoidRabbitOperations.convertAndSend(Object message, MessagePostProcessor messagePostProcessor, CorrelationData correlationData) Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.voidRabbitOperations.convertAndSend(String routingKey, Object message, MessagePostProcessor messagePostProcessor, CorrelationData correlationData) Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.voidRabbitOperations.convertAndSend(String routingKey, Object message, CorrelationData correlationData) Convert a Java object to an AmqpMessageand send it to a default exchange with a specific routing key.voidRabbitOperations.convertAndSend(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.voidRabbitOperations.convertAndSend(String exchange, String routingKey, Object message, CorrelationData correlationData) Convert a Java object to an AmqpMessageand send it to a specific exchange with a specific routing key.voidRabbitTemplate.convertAndSend(Object object) voidRabbitTemplate.convertAndSend(Object message, MessagePostProcessor messagePostProcessor) voidRabbitTemplate.convertAndSend(Object message, MessagePostProcessor messagePostProcessor, CorrelationData correlationData) voidRabbitTemplate.convertAndSend(String routingKey, Object object) voidRabbitTemplate.convertAndSend(String routingKey, Object message, MessagePostProcessor messagePostProcessor) voidRabbitTemplate.convertAndSend(String routingKey, Object message, MessagePostProcessor messagePostProcessor, CorrelationData correlationData) voidRabbitTemplate.convertAndSend(String routingKey, Object object, CorrelationData correlationData) voidRabbitTemplate.convertAndSend(String exchange, String routingKey, Object object) voidRabbitTemplate.convertAndSend(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor) voidRabbitTemplate.convertAndSend(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) voidRabbitTemplate.convertAndSend(String exchange, String routingKey, Object object, @Nullable CorrelationData correlationData) @Nullable ObjectRabbitOperations.convertSendAndReceive(Object message, MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) Basic RPC pattern with conversion.@Nullable ObjectRabbitOperations.convertSendAndReceive(Object message, CorrelationData correlationData) Basic RPC pattern with conversion.@Nullable ObjectRabbitOperations.convertSendAndReceive(String routingKey, Object message, MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) Basic RPC pattern with conversion.@Nullable ObjectRabbitOperations.convertSendAndReceive(String routingKey, Object message, CorrelationData correlationData) Basic RPC pattern with conversion.@Nullable ObjectRabbitOperations.convertSendAndReceive(String exchange, String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) Basic RPC pattern with conversion.@Nullable ObjectRabbitOperations.convertSendAndReceive(String exchange, String routingKey, Object message, CorrelationData correlationData) Basic RPC pattern with conversion.@Nullable ObjectRabbitTemplate.convertSendAndReceive(Object message) @Nullable ObjectRabbitTemplate.convertSendAndReceive(Object message, MessagePostProcessor messagePostProcessor) @Nullable ObjectRabbitTemplate.convertSendAndReceive(Object message, MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) @Nullable ObjectRabbitTemplate.convertSendAndReceive(Object message, @Nullable CorrelationData correlationData) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String routingKey, Object message) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String routingKey, Object message, MessagePostProcessor messagePostProcessor) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String routingKey, Object message, MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String routingKey, Object message, @Nullable CorrelationData correlationData) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String exchange, String routingKey, Object message) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String exchange, String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor) @Nullable ObjectRabbitTemplate.convertSendAndReceive(String exchange, String routingKey, Object message, @Nullable CorrelationData correlationData) <T> @Nullable TRabbitOperations.convertSendAndReceiveAsType(Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TRabbitOperations.convertSendAndReceiveAsType(Object message, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TRabbitOperations.convertSendAndReceiveAsType(String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TRabbitOperations.convertSendAndReceiveAsType(String routingKey, Object message, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TRabbitOperations.convertSendAndReceiveAsType(String exchange, String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.default <T> @Nullable TRabbitOperations.convertSendAndReceiveAsType(String exchange, String routingKey, Object message, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) Basic RPC pattern with conversion.<T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(@Nullable String exchange, @Nullable String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(Object message, @Nullable MessagePostProcessor messagePostProcessor, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(Object message, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(Object message, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(String routingKey, Object message, @Nullable MessagePostProcessor messagePostProcessor, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(String routingKey, Object message, @Nullable CorrelationData correlationData, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(String routingKey, Object message, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(String exchange, String routingKey, Object message, MessagePostProcessor messagePostProcessor, ParameterizedTypeReference<T> responseType) <T> @Nullable TRabbitTemplate.convertSendAndReceiveAsType(String exchange, String routingKey, Object message, ParameterizedTypeReference<T> responseType) voidRabbitOperations.correlationConvertAndSend(Object message, CorrelationData correlationData) Convert a Java object to an AmqpMessageand send it to a default exchange with a default routing key.voidRabbitTemplate.correlationConvertAndSend(Object object, CorrelationData correlationData) <T> @Nullable TRabbitOperations.execute(ChannelCallback<T> action) Execute the callback with a channel and reliably close the channel afterward.default <T> @Nullable TRabbitOperations.invoke(RabbitOperations.OperationsCallback<T> action) Invoke the callback and run all operations on the template argument in a dedicated thread-bound channel and reliably close the channel afterward.@Nullable MessageRabbitTemplate.receive()@Nullable MessageRabbitTemplate.receive(long timeoutMillis) @Nullable ObjectRabbitTemplate.receiveAndConvert()@Nullable ObjectRabbitTemplate.receiveAndConvert(long timeoutMillis) <T> @Nullable TRabbitTemplate.receiveAndConvert(long timeoutMillis, ParameterizedTypeReference<T> type) @Nullable ObjectRabbitTemplate.receiveAndConvert(String queueName) @Nullable ObjectRabbitTemplate.receiveAndConvert(String queueName, long timeoutMillis) <T> @Nullable TRabbitTemplate.receiveAndConvert(String queueName, long timeoutMillis, ParameterizedTypeReference<T> type) <T> @Nullable TRabbitTemplate.receiveAndConvert(String queueName, ParameterizedTypeReference<T> type) <T> @Nullable TRabbitTemplate.receiveAndConvert(ParameterizedTypeReference<T> type) <R,S> boolean RabbitTemplate.receiveAndReply(String queueName, ReceiveAndReplyCallback<R, S> callback) <R,S> boolean RabbitTemplate.receiveAndReply(String queueName, ReceiveAndReplyCallback<R, S> callback, String replyExchange, String replyRoutingKey) <R,S> boolean RabbitTemplate.receiveAndReply(String queueName, ReceiveAndReplyCallback<R, S> callback, ReplyToAddressCallback<S> replyToAddressCallback) <R,S> boolean RabbitTemplate.receiveAndReply(ReceiveAndReplyCallback<R, S> callback) <R,S> boolean RabbitTemplate.receiveAndReply(ReceiveAndReplyCallback<R, S> callback, String exchange, String routingKey) <R,S> boolean RabbitTemplate.receiveAndReply(ReceiveAndReplyCallback<R, S> callback, ReplyToAddressCallback<S> replyToAddressCallback) voidBatchingRabbitTemplate.send(@Nullable String exchange, @Nullable String routingKey, Message message, @Nullable CorrelationData correlationData) voidRabbitOperations.send(String exchange, String routingKey, Message message, @Nullable CorrelationData correlationData) Send a message to a specific exchange with a specific routing key.default voidRabbitOperations.send(String routingKey, Message message, CorrelationData correlationData) Send a message to the default exchange with a specific routing key.voidRabbitTemplate.send(@Nullable String exchange, @Nullable String routingKey, Message message, @Nullable CorrelationData correlationData) voidvoidvoidRabbitTemplate.send(String routingKey, Message message, CorrelationData correlationData) void@Nullable MessageRabbitTemplate.sendAndReceive(String exchange, String routingKey, Message message) @Nullable MessageRabbitTemplate.sendAndReceive(String exchange, String routingKey, Message message, @Nullable CorrelationData correlationData) @Nullable MessageRabbitTemplate.sendAndReceive(String routingKey, Message message) @Nullable MessageRabbitTemplate.sendAndReceive(String routingKey, Message message, @Nullable CorrelationData correlationData) @Nullable MessageRabbitTemplate.sendAndReceive(Message message) @Nullable MessageRabbitTemplate.sendAndReceive(Message message, @Nullable CorrelationData correlationData) booleanRabbitOperations.waitForConfirms(long timeout) Delegate to the underlying dedicated channel to wait for confirms.voidRabbitOperations.waitForConfirmsOrDie(long timeout) Delegate to the underlying dedicated channel to wait for confirms.
- 
Uses of AmqpException in org.springframework.amqp.rabbit.listenerSubclasses of AmqpException in org.springframework.amqp.rabbit.listenerModifier and TypeClassDescriptionclassThis exception indicates that a consumer could not be started because none of its queues are available for listening.Methods in org.springframework.amqp.rabbit.listener that throw AmqpException
- 
Uses of AmqpException in org.springframework.amqp.rabbit.listener.adapterSubclasses of AmqpException in org.springframework.amqp.rabbit.listener.adapterModifier and TypeClassDescriptionclassException to be thrown when the reply of a message failed to be sent.
- 
Uses of AmqpException in org.springframework.amqp.rabbit.listener.exceptionSubclasses of AmqpException in org.springframework.amqp.rabbit.listener.exceptionModifier and TypeClassDescriptionclassException to be thrown when the execution of a listener method failed with an irrecoverable problem.classException to be thrown when the execution of a listener method failed on startup.classException class that indicates a rejected message on shutdown.
- 
Uses of AmqpException in org.springframework.amqp.rabbit.supportSubclasses of AmqpException in org.springframework.amqp.rabbit.supportModifier and TypeClassDescriptionclassException to be thrown when the execution of a listener method failed.
- 
Uses of AmqpException in org.springframework.amqp.support.converterSubclasses of AmqpException in org.springframework.amqp.support.converterModifier and TypeClassDescriptionclassException to be thrown by message converters if they encounter a problem with converting a message or object.
- 
Uses of AmqpException in org.springframework.amqp.support.postprocessorMethods in org.springframework.amqp.support.postprocessor that throw AmqpExceptionModifier and TypeMethodDescriptionAbstractCompressingPostProcessor.postProcessMessage(Message message) AbstractDecompressingPostProcessor.postProcessMessage(Message message) DelegatingDecompressingPostProcessor.postProcessMessage(Message message) 
- 
Uses of AmqpException in org.springframework.rabbit.stream.producerSubclasses of AmqpException in org.springframework.rabbit.stream.producerModifier and TypeClassDescriptionclassUsed to complete the future exceptionally when sending fails.Methods in org.springframework.rabbit.stream.producer that throw AmqpException