Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
I
- id() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitListener
- 
The unique identifier of the container managing for this endpoint.
- ignoreDeclarationExceptions() - Method in class org.springframework.amqp.core.ExchangeBuilder
- 
Switch on ignore exceptions such as mismatched properties when declaring.
- ignoreDeclarationExceptions() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
- ignoreDeclarationExceptions() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Queue
- ignoreDeclarationExceptions() - Element in annotation interface org.springframework.amqp.rabbit.annotation.QueueBinding
- ImmediateAcknowledgeAmqpException - Exception in org.springframework.amqp
- 
Special exception for listener implementations that want to signal that the current batch of messages should be acknowledged immediately (i.e.
- ImmediateAcknowledgeAmqpException(String) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
- ImmediateAcknowledgeAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
- ImmediateAcknowledgeAmqpException(Throwable) - Constructor for exception org.springframework.amqp.ImmediateAcknowledgeAmqpException
- ImmediateRequeueAmqpException - Exception in org.springframework.amqp
- 
The specialAmqpExceptionto be thrown from the listener (e.g.
- ImmediateRequeueAmqpException(String) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
- ImmediateRequeueAmqpException(String, Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
- ImmediateRequeueAmqpException(Throwable) - Constructor for exception org.springframework.amqp.ImmediateRequeueAmqpException
- ImmediateRequeueMessageRecoverer - Class in org.springframework.amqp.rabbit.retry
- 
TheMessageRecovererimplementation to throw anImmediateRequeueAmqpExceptionfor subsequent requeuing in the listener container.
- ImmediateRequeueMessageRecoverer() - Constructor for class org.springframework.amqp.rabbit.retry.ImmediateRequeueMessageRecoverer
- incrementRetries() - Method in class org.springframework.amqp.rabbit.log4j2.AmqpAppender.Event
- incrementRetries() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender.Event
- INFERRED - Enum constant in enum class org.springframework.amqp.support.converter.Jackson2JavaTypeMapper.TypePrecedence
- InflaterPostProcessor - Class in org.springframework.amqp.support.postprocessor
- 
A post processor that uses aInflaterInputStreamto decompress the message body.
- InflaterPostProcessor() - Constructor for class org.springframework.amqp.support.postprocessor.InflaterPostProcessor
- InflaterPostProcessor(boolean) - Constructor for class org.springframework.amqp.support.postprocessor.InflaterPostProcessor
- init() - Method in class org.springframework.amqp.rabbit.config.RabbitNamespaceHandler
- initArgumentResolvers() - Method in class org.springframework.amqp.rabbit.listener.adapter.AmqpMessageHandlerMethodFactory
- initDefaultStrategies() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Set up the default strategies.
- initGateway() - Method in class org.springframework.amqp.rabbit.core.RabbitGatewaySupport
- 
Subclasses can override this for custom initialization behavior.
- initialize() - Method in interface org.springframework.amqp.core.AmqpAdmin
- 
Initialize the admin.
- initialize() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- 
Declares all the exchanges, queues and bindings in the enclosing application context, if any.
- initialize() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Initialize this container.
- initializeConsumers() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
- initializeContainer(C, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.AbstractRabbitListenerContainerFactory
- 
Further initialize the specified container.
- initializeContainer(DirectMessageListenerContainer, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.DirectRabbitListenerContainerFactory
- initializeContainer(SimpleMessageListenerContainer, RabbitListenerEndpoint) - Method in class org.springframework.amqp.rabbit.config.SimpleRabbitListenerContainerFactory
- initializeProxy(Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- INORDER - Enum constant in enum class org.springframework.amqp.rabbit.connection.AbstractConnectionFactory.AddressShuffleMode
- 
Shuffle the addresses after opening a connection, moving the first address to the end.
- INSTANCE - Static variable in class org.springframework.amqp.rabbit.support.micrometer.RabbitListenerObservation.DefaultRabbitListenerObservationConvention
- 
A singleton instance of the convention.
- INSTANCE - Static variable in class org.springframework.amqp.rabbit.support.micrometer.RabbitTemplateObservation.DefaultRabbitTemplateObservationConvention
- 
A singleton instance of the convention.
- INSTANCE - Static variable in class org.springframework.amqp.utils.JavaUtils
- 
The singleton instance of this utility class.
- INSTANCE - Static variable in class org.springframework.rabbit.stream.micrometer.RabbitStreamListenerObservation.DefaultRabbitStreamListenerObservationConvention
- 
A singleton instance of the convention.
- INSTANCE - Static variable in class org.springframework.rabbit.stream.micrometer.RabbitStreamMessageReceiverContext.DefaultRabbitListenerObservationConvention
- 
A singleton instance of the convention.
- INSTANCE - Static variable in class org.springframework.rabbit.stream.micrometer.RabbitStreamTemplateObservation.DefaultRabbitStreamTemplateObservationConvention
- 
A singleton instance of the convention.
- internal() - Method in class org.springframework.amqp.core.ExchangeBuilder
- 
Set the internal flag.
- internal() - Element in annotation interface org.springframework.amqp.rabbit.annotation.Exchange
- InvocationData(MethodInvocation, Object) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
- InvocationData(MethodInvocation, Throwable) - Constructor for class org.springframework.amqp.rabbit.test.RabbitListenerTestHarness.InvocationData
- InvocationResult - Class in org.springframework.amqp.rabbit.listener.adapter
- 
The result of a listener method invocation.
- InvocationResult(Object, Expression, Type, Object, Method) - Constructor for class org.springframework.amqp.rabbit.listener.adapter.InvocationResult
- 
Construct an instance with the provided properties.
- invoke(RabbitOperations.OperationsCallback<T>) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Invoke the callback and run all operations on the template argument in a dedicated thread-bound channel and reliably close the channel afterwards.
- invoke(RabbitOperations.OperationsCallback<T>, ConfirmCallback, ConfirmCallback) - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- 
Invoke operations on the same channel.
- invoke(RabbitOperations.OperationsCallback<T>, ConfirmCallback, ConfirmCallback) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- invoke(Message<?>, Object...) - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
- 
Invoke the method with the given message.
- invoke(Message<?>, Object...) - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
- 
Invoke the appropriate method for the payload.
- invokeErrorHandler(Throwable) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Invoke the registered ErrorHandler, if any.
- invokeHandlerAndProcessResult(Message, Channel, Message<?>) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
- invokeListener(Channel, Object) - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- invokeListenerMethod(String, Object[], Message) - Method in class org.springframework.amqp.rabbit.listener.adapter.MessageListenerAdapter
- 
Invoke the specified listener method.
- isAck() - Method in class org.springframework.amqp.rabbit.connection.CorrelationData.Confirm
- isActive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isActive() - Method in class org.springframework.amqp.rabbit.support.ActiveObjectCounter
- isAddMdcAsHeaders() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isAlwaysRequeueWithTxManagerRollback() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isAmqpMessageList() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
- isAsyncReplies() - Method in interface org.springframework.amqp.core.MessageListener
- 
Return true if this listener is request/reply and the replies are async.
- isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.adapter.DelegatingInvocableHandler
- 
Return true if any handler method has an async reply type.
- isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.adapter.HandlerAdapter
- 
Return true if any handler method has an async reply type.
- isAsyncReplies() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter
- isAttributeDefined(Element, String) - Static method in class org.springframework.amqp.rabbit.config.NamespaceUtils
- 
Checks the attribute to see if it is defined in the given element.
- isAutoAck() - Method in enum class org.springframework.amqp.core.AcknowledgeMode
- 
Return if the mode isAcknowledgeMode.NONE(which is calledautoAckin RabbitMQ).
- isAutoDeclare() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isAutoDelete() - Method in class org.springframework.amqp.core.AbstractExchange
- isAutoDelete() - Method in interface org.springframework.amqp.core.Exchange
- 
True if the server should delete the exchange when it is no longer in use (if all bindings are deleted).
- isAutoDelete() - Method in class org.springframework.amqp.core.Queue
- 
True if the server should delete the queue when it is no longer in use (the last consumer is cancelled).
- isAutoDelete() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isAutoStartup() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- isAutoStartup() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- isAutoStartup() - Method in class org.springframework.rabbit.stream.support.StreamAdmin
- isBatchListener() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- 
True if this endpoint is for a batch listener.
- isBrokerAndManagementRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- isBrokerAndManagementRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- isBrokerAndManagementRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- isBrokerAndManagementRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- isChannelLocallyTransacted() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this listener container's Channel handling and not by an external transaction coordinator.
- isChannelLocallyTransacted(Channel) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Check whether the given Channel is locally transacted, that is, whether its transaction is managed by this template's Channel handling and not by an external transaction coordinator.
- isChannelTransacted() - Method in class org.springframework.amqp.rabbit.connection.RabbitAccessor
- isChannelTransactional(Channel, ConnectionFactory) - Static method in class org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils
- 
Determine whether the given RabbitMQ Channel is transactional, that is, bound to the current thread by Spring's transaction facilities.
- isConfirmListener() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
- isConfirmListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- isConfirmSelected() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
- 
Return true if confirms are selected on this channel.
- isConsumerBatchEnabled() - Method in interface org.springframework.amqp.rabbit.listener.MessageListenerContainer
- 
Return true if this container is capable of (and configured to) create batches of consumed messages.
- isConsumerBatchEnabled() - Method in class org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer
- isContentLengthSet() - Method in class org.springframework.amqp.core.MessageProperties
- isConverterWinsContentType() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- isConverterWinsContentType() - Method in class org.springframework.amqp.rabbit.listener.adapter.AbstractAdaptableMessageListener
- 
Return whether the content type set by a converter prevails or not.
- isConverterWinsContentType() - Method in interface org.springframework.amqp.rabbit.listener.RabbitListenerEndpoint
- 
Return whether the content type set by a converter prevails or not.
- isCreateMessageIds() - Method in class org.springframework.amqp.support.converter.AbstractMessageConverter
- 
Flag to indicate that new messages should have unique identifiers added to their properties before sending.
- isDeBatchingEnabled() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isDeclareExchange() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isDefault() - Element in annotation interface org.springframework.amqp.rabbit.annotation.RabbitHandler
- 
When true, designate that this is the default fallback method if the payload type matches no otherRabbitHandlermethod.
- isDefaultRequeueRejected() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Return the default requeue rejected.
- isDelayed() - Method in class org.springframework.amqp.core.AbstractExchange
- isDelayed() - Method in interface org.springframework.amqp.core.Exchange
- 
Is a delayed message exchange; currently requires a broker plugin.
- isDeliveryTagSet() - Method in class org.springframework.amqp.core.MessageProperties
- isDestinationQueue() - Method in class org.springframework.amqp.core.Binding
- isDiscardFatalsWithXDeath() - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
- 
Return the discardFatalsWithXDeath.
- isDurable() - Method in class org.springframework.amqp.core.AbstractExchange
- isDurable() - Method in interface org.springframework.amqp.core.Exchange
- 
A durable exchange will survive a server restart.
- isDurable() - Method in class org.springframework.amqp.core.Queue
- 
A durable queue will survive a server restart.
- isDurable() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isExchangeDeclarationFailure(Exception) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Return true if there is aShutdownSignalExceptionin the cause tree and its reason is "COMMAND_INVALID" and the operation being performed was exchangeDeclare.
- isExclusive() - Method in class org.springframework.amqp.core.Queue
- 
True if the server should only send messages to the declarer's connection.
- isExclusive() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Return whether the consumers should be exclusive.
- isExclusive() - Method in class org.springframework.amqp.rabbit.listener.AbstractRabbitListenerEndpoint
- isExclusiveUseChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Return true if theShutdownSignalExceptionreason is AMQP.Channel.Close and the operation that failed was basicConsumer and the failure text contains "exclusive".
- isExistingTransaction(Object) - Method in class org.springframework.amqp.rabbit.transaction.RabbitTransactionManager
- isExposeListenerChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isFatal() - Method in class org.springframework.amqp.rabbit.listener.ListenerContainerConsumerFailedEvent
- isFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
- isFatal(Throwable) - Method in interface org.springframework.amqp.rabbit.listener.FatalExceptionStrategy
- isFinalRetryForMessageWithNoId() - Method in class org.springframework.amqp.core.MessageProperties
- isForceCloseChannel() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Force close the channel if the consumer threads don't respond to a shutdown.
- isForceStop() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Stop container after current message(s) are processed and requeue any prefetched.
- isGenerateId() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isGlobalQos() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isIgnoreDeclarationExceptions() - Method in class org.springframework.amqp.core.AbstractDeclarable
- isIgnoreDeclarationExceptions() - Method in interface org.springframework.amqp.core.Declarable
- 
Should ignore exceptions (such as mismatched args) when declaring.
- isIncludeCallerData() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isInternal() - Method in class org.springframework.amqp.core.AbstractExchange
- isInternal() - Method in interface org.springframework.amqp.core.Exchange
- 
Is an exchange internal; i.e.
- isLastInBatch() - Method in class org.springframework.amqp.core.MessageProperties
- 
When true; the message having these properties is the last message from a batch.
- isLenientFallback() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- isMandatoryFor(Message) - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
Return whether the provided message should be sent with the mandatory flag set.
- isManual() - Method in enum class org.springframework.amqp.core.AcknowledgeMode
- 
Return true if the mode isAcknowledgeMode.MANUAL.
- isMessageList() - Method in class org.springframework.amqp.rabbit.listener.adapter.MessagingMessageListenerAdapter.MessagingMessageConverterAdapter
- isMismatchedQueueArgs(Exception) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Return true if there is aShutdownSignalExceptionin the cause tree and its reason is "PRECONDITION_FAILED" and the operation being performed was queueDeclare.
- isMismatchedQueuesFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isMissingQueuesFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isMissingQueuesFatalSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isNew(Message) - Method in interface org.springframework.amqp.rabbit.retry.NewMessageIdentifier
- 
Query a message to see if it has been seen before.
- isNoLocal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Return whether the consumers should be no-local.
- isNormalCancel() - Method in class org.springframework.amqp.rabbit.listener.BlockingQueueConsumer
- 
Return true if cancellation is expected.
- isNormalChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Return true if theShutdownSignalExceptionreason is AMQP.Channel.Close and the reply code was AMQP.REPLY_SUCCESS (200) and the text equals "OK".
- isNormalShutdown(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Return true if theShutdownSignalExceptionreason is AMQP.Connection.Close and the reply code was AMQP.REPLY_SUCCESS (200) and the text equals "OK".
- isNotRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- isNotRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- isOpen() - Method in interface org.springframework.amqp.rabbit.connection.Connection
- 
Flag to indicate the status of the connection.
- isOpen() - Method in class org.springframework.amqp.rabbit.connection.PublisherCallbackChannelImpl
- isOpen() - Method in class org.springframework.amqp.rabbit.connection.SimpleConnection
- 
True if the connection is open.
- isPassiveDeclarationChannelClose(ShutdownSignalException) - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Return true if theShutdownSignalExceptionreason is AMQP.Channel.Close and the operation that failed was exchangeDeclare or queueDeclare.
- isPhysicalCloseRequired() - Static method in class org.springframework.amqp.rabbit.connection.RabbitUtils
- 
Gets and removes a ThreadLocal indicating the channel MUST be physically closed.
- isPossibleAuthenticationFailureFatal() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isPossibleAuthenticationFailureFatalSet() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isProjectionUsed() - Method in class org.springframework.amqp.core.MessageProperties
- 
Get an internal flag used to communicate that conversion used projection; always false at the application level.
- isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- isPublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- isPublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
- 
Return true if publisher confirms are enabled.
- isPublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
- 
Return true if publisher confirms are enabled.
- isPublisherReturns() - Method in class org.springframework.amqp.rabbit.connection.AbstractRoutingConnectionFactory
- isPublisherReturns() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- isPublisherReturns() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
- 
Return true if publisher returns are enabled.
- isPurgeAfterEach() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- isRedeclareManualDeclarations() - Method in class org.springframework.amqp.rabbit.core.RabbitAdmin
- 
Normally, when a connection is recovered, the admin only recovers auto-delete queues, etc, that are declared as beans in the application context.
- isRedelivered() - Method in class org.springframework.amqp.core.MessageProperties
- isRejectManual() - Method in exception org.springframework.amqp.AmqpRejectAndDontRequeueException
- 
True if the container should reject the message, even with manual acks.
- isRejectManual() - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler
- 
Return the rejectManual.
- isRejectManual(Throwable) - Static method in class org.springframework.amqp.rabbit.listener.support.ContainerUtils
- 
Return true forAmqpRejectAndDontRequeueException.isRejectManual().
- isReleaseAfterCompletion() - Method in class org.springframework.amqp.rabbit.connection.RabbitResourceHolder
- 
Whether the resources should be released after transaction completion.
- isReturned() - Method in class org.springframework.amqp.rabbit.connection.PendingConfirm
- 
True if a returned message has been received.
- isReturnListener() - Method in interface org.springframework.amqp.rabbit.connection.PublisherCallbackChannel.Listener
- isReturnListener() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- isRunning() - Method in class org.springframework.amqp.rabbit.AsyncRabbitTemplate
- isRunning() - Method in class org.springframework.amqp.rabbit.config.ListenerContainerFactoryBean
- isRunning() - Method in class org.springframework.amqp.rabbit.core.BatchingRabbitTemplate
- isRunning() - Method in class org.springframework.amqp.rabbit.core.BrokerEventListener
- isRunning() - Method in interface org.springframework.amqp.rabbit.core.RabbitOperations
- isRunning() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- isRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- isRunning() - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- isRunning() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- 
Determine whether this container is currently running, that is, whether it has been started and not stopped yet.
- isRunning() - Method in class org.springframework.amqp.rabbit.listener.RabbitListenerEndpointRegistry
- isRunning() - Method in class org.springframework.rabbit.stream.listener.StreamListenerContainer
- isRunning() - Method in class org.springframework.rabbit.stream.support.StreamAdmin
- isRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- 
Ensure the broker is running and has a empty queue(s) with the specified name(s) in the default exchange.
- isRunningWithEmptyQueues(String...) - Static method in class org.springframework.amqp.rabbit.junit.BrokerRunningSupport
- 
Ensure the broker is running and has a empty queue(s) with the specified name(s) in the default exchange.
- isShouldRun() - Method in class org.springframework.amqp.rabbit.junit.LongRunningIntegrationTest
- 
Return true if the test should run.
- isSimplePublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.CachingConnectionFactory
- isSimplePublisherConfirms() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactory
- 
Return true if simple publisher confirms are enabled.
- isSimplePublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.PooledChannelConnectionFactory
- isSimplePublisherConfirms() - Method in class org.springframework.amqp.rabbit.connection.ThreadChannelConnectionFactory
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.AbstractRetryOperationsInterceptorFactoryBean
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.BindingFactoryBean
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.StatefulRetryOperationsInterceptorFactoryBean
- isSingleton() - Method in class org.springframework.amqp.rabbit.config.StatelessRetryOperationsInterceptorFactoryBean
- isSkipServerCertificateValidation() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- 
Whether or not Server Side certificate has to be validated or not.
- isStatefulRetryFatalWithNullMessageId() - Method in class org.springframework.amqp.rabbit.listener.AbstractMessageListenerContainer
- isSynchedLocalTransactionAllowed() - Method in interface org.springframework.amqp.rabbit.connection.ConnectionFactoryUtils.ResourceFactory
- 
Return whether to allow for a local RabbitMQ transaction that is synchronized with a Spring-managed transaction (where the main transaction might be a JDBC-based one for a specific DataSource, for example), with the RabbitMQ transaction committing right after the main transaction.
- isTransactional() - Method in interface org.springframework.amqp.rabbit.connection.ChannelProxy
- 
Return whether this channel has transactions enabledtxSelect().
- isTransactionAllowed() - Method in enum class org.springframework.amqp.core.AcknowledgeMode
- 
Return if transactions are allowed - if the mode isAcknowledgeMode.AUTOorAcknowledgeMode.MANUAL.
- isTypeMapperSet() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- 
Whether or not an explicit java type mapper has been provided.
- isUp() - Method in class org.springframework.amqp.rabbit.junit.BrokerRunning
- isUseProjectionForInterfaces() - Method in class org.springframework.amqp.support.converter.AbstractJackson2MessageConverter
- isUsePublisherConnection() - Method in class org.springframework.amqp.rabbit.core.RabbitTemplate
- 
True if separate publisher connection(s) are used.
- isUserCauseFatal(Throwable) - Method in class org.springframework.amqp.rabbit.listener.ConditionalRejectingErrorHandler.DefaultExceptionStrategy
- 
Subclasses can override this to add custom exceptions.
- isUseSsl() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- isUseSSL() - Method in class org.springframework.amqp.rabbit.connection.RabbitConnectionFactoryBean
- isVerifyHostname() - Method in class org.springframework.amqp.rabbit.logback.AmqpAppender
- 
Return true (default) if TLS hostname verification is enabled.
- isWritable(Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
- isWritable(EvaluationContext) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
- isWritable(EvaluationContext, Object) - Method in class org.springframework.amqp.rabbit.support.ValueExpression
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form