All Classes and Interfaces
Class
Description
Stage responsible for executing the
AsyncMessageInterceptors after message processing.AbstractAwsConfigDataLocationResolver<T extends org.springframework.boot.context.config.ConfigDataResource>
Base class for AWS specific
ConfigDataLocationResolvers.Stage responsible for executing the
AsyncMessageInterceptors before message processing.Base implementation for
ContainerOptions.AbstractContainerOptions.Builder<B extends ContainerOptionsBuilder<B,O>,O extends ContainerOptions<O,B>>
Generates AbstractCrossRegionS3Client class from
AbstractCrossRegionS3ClientTemplate.MessageProcessingPipelineSink implementation that delegates method invocations to the provided delegate.Base class for implementing a
HandlerMethodEndpoint.BeanPostProcessor implementation that scans beans for a @SqsListener annotation, extracts
information to a SqsEndpoint, and registers it in the EndpointRegistrar.A
MessageSource implementation capable of converting messages from a Source type to a Target type.AbstractMessageListenerContainer<T,O extends ContainerOptions<O,B>,B extends ContainerOptionsBuilder<B,O>>
Base implementation for
MessageListenerContainer with SmartLifecycle and component management
capabilities.AbstractMessageListenerContainerFactory<T,C extends MessageListenerContainer<T>,O extends ContainerOptions<O,B>,B extends ContainerOptionsBuilder<B,O>>
Base implementation for a
MessageListenerContainerFactory.Base implementation for
MessageProcessingPipelineSink containing SmartLifecycle features and useful
execution methods that can be used by subclasses.Base
MessagingMessageConverter implementation.Base class for
MessagingOperationsBase class for template options, to be extended by subclasses.
Base class for invoking an
InvocableHandlerMethod.Base implementation for a
AcknowledgementProcessor with SmartLifecycle
capabilities.AbstractPipelineMessageListenerContainer<T,O extends ContainerOptions<O,B>,B extends ContainerOptionsBuilder<B,O>>
Base
MessageListenerContainer implementation for managing Message
instances' lifecycles.Base
PollingMessageSource implementation with SmartLifecycle
capabilities.MessageSource implementation for polling messages from a SQS queue and converting them to messaging
Message.Interface representing a message acknowledgement.
MessageConversionContext specialization that enables setting an AcknowledgementCallback to be used
when mapping acknowledgement related properties.Interface representing an acknowledgement callback to be executed, usually by a
AcknowledgementHandler implementation.Allows executing acknowledgements for a batch of messages.
Interface for managing acknowledgement in success and failure scenarios.
Stage responsible for executing the
AcknowledgementHandler.Configures the acknowledgement behavior for this container.
Configures the ordering of acknowledgements.
MessageSource specialization that enables processing acknowledgements for the
Message instances through an
AcknowledgementExecutorTop-level interface for a component capable of processing acknowledgements.
Provides actions to be executed after a message acknowledgement completes with either success or failure.
Exception representing a failure to execute a
AcknowledgementResultCallback.HandlerMethodArgumentResolver implementation for resolving Acknowledgement arguments.Stage responsible for executing the
AsyncMessageInterceptor instances from the
MessageProcessingContext after message processing.Stage responsible for executing the
AsyncMessageInterceptors after message processing.AcknowledgementHandler implementation that acknowledges on both success and error.Secrets from the Secret Manager are added to the
Environment and can be retrieved using: - Value
annotation - PropertyResolver.getProperty(String) - or bound to ConfigurationProperties annotated classes.Provides actions to be executed after a message acknowledgement completes with either success or failure.
Exception representing a failure on an execution attempted by a blocking adapter.
Utility class for adapting blocking components to their asynchronous variants.
Base class for BlockingComponentAdapters.
Interface for handling message processing errors async.
Async interface for intercepting messages before and after execution.
Async listener to process individual
Message instances.AsyncMessageListener implementation to handle a message by invoking a method handler.Asynchronous messaging operations.
Auto-configuration imports for typical SQS tests.Autoconfigures AWS environment.
Provides a convenience method to apply common configuration to any
AwsClientBuilder.Base properties for AWS Service client.
Configuration properties for AWS environment.
Base class for all AWS loaded property sources.
Abstraction to handle backpressure within a
PollingMessageSource.Configuration for application throughput.
Enables acknowledging messages for
ListenerMode.BATCH.HandlerMethodArgumentResolver implementation for resolving BatchAcknowledgement arguments.BackPressureHandler specialization that allows requesting and releasing batches.AcknowledgementProcessor implementation that adds the messages
to a BlockingQueue to be acknowledged according to ContainerOptions.getAcknowledgementInterval() and
ContainerOptions.getAcknowledgementThreshold().MessageSink implementation that emits the whole received batch of messages to the configured
MessageProcessingPipeline.HandlerMethodArgumentResolver implementation for resolving List arguments.Stage responsible for executing the
AsyncMessageInterceptors from the MessageProcessingContext before
message processing.Stage responsible for executing the
AsyncMessageInterceptors before message processing.Utility class for setting up logging in objects registered in
BootstrapRegistry.Caching implementation for resolving ARN from topicName.
Configuration for exporting metrics to CloudWatch.
ConfigurationProperties for configuring CloudWatch client.ConfigurationProperties for configuring CloudWatch metrics export.Utility methods for using convenient
CompletableFuture methods from later JDK versions in Java 8.Representation of a
MessageListenerContainer component that can be configured using a
ContainerOptions instance.This is the superclass of all beans that can listen to changes in the configuration and fire a reload.
This is the superclass of all named strategies that can be fired when the configuration changes.
Utility class for conditional configurations.
A factory for creating components for the
MessageListenerContainer.Contains the options to be used by the
MessageListenerContainer at runtime.A builder for creating a
ContainerOptions instance.A
HeaderMapper specialization that supports receiving a MessageConversionContext for mapping context
dependent headers.A
MessagingMessageConverter specialization that enables receving a MessageConversionContext that can
be used to add context specific properties to the converted message.Properties related to AWS credentials.
EnableAutoConfiguration for AwsCredentialsProvider.Properties used to configure
ClusterDaxClientSimple implementation of
DynamoDbTableNameResolver that resolves class simple name to table name.Default implementation with simple cache for
TableSchema.MessageListenerContainerRegistry implementation that registers the MessageListenerContainer instances
and manage their lifecycle.Default implementation of
TopicArnResolver used to determine topic ARN by name.Creates
DiskBufferingS3OutputStream.Auto-configuration for DynamoDB integration.Interface for simple DynamoDB template operations.
Properties related to AWS DynamoDB.
Resolves DynamoDB table name from a
Class.Resolving Class and TableName to
TableSchema class.Default implementation of
DynamoDbOperations.Represents a messaging endpoint from which messages can be consumed by a
MessageListenerContainer.Processes the registered
Endpoint instances using the appropriate MessageListenerContainerFactory.Interface for handling errors.
Stage responsible for executing the
AsyncErrorHandler after a failed
MessageListener execution.AcknowledgementProcessor specialization that allows for delegating acknowledgement execution to a
AcknowledgementExecutor.MessageProcessingPipelineSink implementation that executes messages from the provided batch in parallel.ContainerComponentFactory implementation for creating components for FIFO queues.AbstractSqsMessageSource implementation for FIFO queues.Methods related to FIFO queues.
An example on how to create file upload to S3.
Endpoint specialization that indicates that Message instances coming
from this endpoint will be handled by a HandlerMethod.Mapper interface to map from and to
MessageHeaders and a given source type.Representation of a component that can be assigned an id.
S3OutputStream implementation that buffers content to an internal ByteArrayOutputStream and streams
the content as a MultiPartUpload as the buffer fills up.Creates
InMemoryBufferingS3OutputStream.Jackson based implementation of
S3ObjectConverter.Handler for lifecycle methods.
Exception thrown when the
AsyncMessageListener completes with an exception.Configure the delivery strategy to be used by a
MessageListenerContainer.Represents S3 bucket or object location.
A sample application to demonstrate sending simple emails and emails with attachments.
Helper class used for conversion between
MessageAttributeValue and Java types.Marker interface for a message conversion context.
A
Thread implementation for processing messages.CustomizableThreadFactory implementation for creating MessageExecutionThread instances.AbstractDelegatingMessageListeningSinkAdapter implementation that groups the received batch according to the
provided grouping function and emits each sub batch to the delegate separately.Utility class for extracting
MessageHeaders from a Message.Interface for intercepting messages before and after execution.
Interface to process incoming
Messages.A container for an
AsyncMessageListener with SmartLifecycle capabilities.Creates
MessageListenerContainer instances for given Endpoint instances or endpoint names.Interface for registering and looking up containers at startup and runtime.
Stage responsible for executing the
AsyncMessageListener.Holds the components that will be used on the
MessageProcessingPipeline.A message processing context that can be used for communication between components.
Represents a stage in the processing pipeline that will be used to process
Message instances.Entrypoint for constructing a
MessageProcessingPipeline MessageProcessingPipelineBuilder.ComposingMessagePipelineStage.MessageSink specialization that uses a MessageProcessingPipeline as the output.Component that handles the flow of
Messages.A source of
Message instances.An
AbstractDelegatingMessageListeningSinkAdapter that adds an
MessageVisibilityExtendingSinkAdapter<T>.io.awspring.cloud.sqs.listener.sink.adapter.MessageVisibilityExtendingSinkAdapter.OriginalBatchMessageVisibilityExtendingInterceptor to the MessageProcessingContext.MessageHeaders associated with messaging operations.A converter for converting source or target objects to and from Spring Messaging
Messages.MessageHeaders implementation that allows providing an external UUID.MessageListener implementation to handle a message by invoking a method
handler.Exception to represent the failure of a Messaging Operation.
Synchronous messaging operations.
Options to be used by the template.
AcknowledgementHandler implementation that never acknowledges regardless of the result.Simple util class that is used to create handlers for Http/s notification support.
Annotation that is used to map SNS notification value to a variable that is annotated.
Handles conversion of SNS notification value to a variable that is annotated with
NotificationMessage.Spring Web MVC request mapping that supports Amazon SNS HTTP endpoints using the Spring Controller model.
Interface used for confirming Subscription/Unsubscription.
Handles Subscription and Unsubscription events by transforming them to
NotificationStatus which can be used
to confirm Subscriptions/Subscriptions.Annotation that is used to map SNS subject value to a variable that is annotated.
Handles conversion of SNS subject value to a variable that is annotated with
NotificationSubject.Spring Web MVC request mapping that supports Amazon SNS HTTP endpoint subscriptions using the Spring Controller
model.
Spring Web MVC request mapping that supports Amazon SNS HTTP endpoint subscriptions using the Spring Controller
model.
Container for S3 Object Metadata.
Stores regular Java objects as S3 files.
AcknowledgementHandler implementation that only acknowledges on success.MessageProcessingPipelineSink implementation that processes provided messages sequentially and in order.ConfigDataLoader for AWS Parameter Store.Config data resource for AWS System Manager Management integration.
Thrown when configuration provided to ConfigDataLoader is missing parameter store keys, for example
`spring.config.import=aws-parameterstore:`.
An
AbstractFailureAnalyzer that performs analysis of a Parameter Store configuration failure caused by not
providing a Parameter Store key to `spring.config.import` property.Configuration properties for the AWS Parameter Store integration.
Recursively retrieves all parameters under the given context / path with decryption from the AWS Parameter Store
using the provided SSM client.
Auto-Configuration for reloading properties from Parameter Store.Configuration change detector that checks for changed configuration on a scheduled basis.
MessageSource extension that provides polling configurations and SmartLifecycle capabilities.Properties related to AWS Profile.
Resolves content type for S3 object from a properties file.
Queue attributes extracted from SQS, as well as the queue name and url.
Implementations are enabled to receive a
QueueAttributes instance.HandlerMethodArgumentResolver implementation for resolving QueueAttributes arguments.Resolves
QueueAttributes for the specified queue.A builder for creating
QueueAttributesResolver instances.Exception thrown when a
QueueAttributesResolver fails.Visibility implementation for SQS messages.Configure the strategy to be used when a specified queue is not found at container startup.
Properties related to AWS region configuration.
EnableAutoConfiguration for AwsRegionProvider.Configuration related to reloading properties.
Configuration for reload strategies.
EnableAutoConfiguration for S3Client based
S3AsyncClient.Properties related to
S3CrtAsyncClient.Exception thrown when S3 operation fails.
Resolves content type of S3 objects.
Converter used to serialize Java objects into S3 objects.
Higher level abstraction over
S3Client providing methods for the most common use cases.Represents
OutputStream that writes data to S3.Creates an
OutputStream that writes data to S3.A
ResourcePatternResolver implementation which allows an ant-style path matching when loading S3 resources.Properties related to AWS S3.
Resolves
S3Resource for resources paths starting from s3://.Resource implementation for S3 objects.Higher level abstraction over
S3Client providing methods for the most common use cases.EnableAutoConfiguration for S3TransferManagerProperties related to AWS S3
S3TransferManager.Loads config data from AWS Secret Manager.
Resolves config data locations in AWS Secrets Manager.
Config data resource for AWS Secret Manager integration.
Thrown when configuration provided to ConfigDataLoader is missing Secrets Manager keys, for example
`spring.config.import=aws-secretsmanager:`.
An
AbstractFailureAnalyzer that performs analysis of a Secrets Manager configuration failure caused by not
providing a Secrets Manager key to `spring.config.import` property.Configuration properties for the AWS Secrets Manager integration.
Retrieves secret value under the given context / path from the AWS Secrets Manager using the provided Secrets Manager
client.
Provides prefix config import support.
Auto-Configuration for reloading properties from Secrets Manager.BackPressureHandler implementation that uses a Semaphore for handling backpressure.The strategy to use when handling a send batch operation that has at least one failed message.
Exception representing a partial or complete failure in sending a batch of messages to an endpoint.
The result of a send operation.
The result of a batch send operation.
The result of a failed send operation.
Properties related to AWS Simple Email Service.
JavaMailSender implementation that allows to send MimeMessage using the Simple E-Mail Service.Simple MailSender implementation to send E-Mails with the Amazon Simple Email Service.
Helper class that is transformed to
MessageAttributeValue when sending SMS via SNS.The type of message that you're sending.
Auto-configuration for SNS integration.SNS specific headers that can be applied to Spring Messaging
Message.SNS notification object.
High level SNS operations.
Properties related to AWS SNS.
High level SNS operations for sending SMS.
Helper class abstraction over
SnsClient tailored for sending SMS messages to SNS topics and phone numbers.Helper class that simplifies synchronous sending of notifications to SNS.
Utility class for creating
ClientOverrideConfiguration containing "Spring Cloud AWS" user agent.Exception representing an error during acknowledgement execution.
AcknowledgementExecutor implementation for SQS queues.Implementations are enabled to receive a
SqsAsyncClient instance.Sqs-specific asynchronous messaging operations for Standard and Fifo queues.
Auto-configuration for SQS integration.Utility class containing the bean names used for the framework's bean registration.
Registers the
DefaultListenerContainerRegistry and EndpointRegistrar that will be used to bootstrap
the AWS SQS integration.Sqs specific implementation of
ContainerOptions.ContainerOptionsBuilder specialization for SQS specific options.Endpoint implementation for SQS endpoints.Top-level exception for Sqs
RuntimeException instances.A
HeaderMapper implementation for SQS Messages.The
MessageHeaders names used for Message
instances created from SQS messages.Methods with this annotation will be wrapped by a
MessageListener or
AsyncMessageListener and set to a
MessageListenerContainer.AbstractListenerAnnotationBeanPostProcessor implementation for @SqsListener.Beans implementing this interface can configure the
EndpointRegistrar instance used to process
Endpoint instances and change general settings for processing all
SqsListener annotations.MessageConversionContext implementation that contains SQS related properties for mapping additional
MessageHeaders.MessageListenerContainer implementation for SQS queues.MessageListenerContainerFactory implementation for creating SqsMessageListenerContainer instances.Resolves original SQS message object {@link (software.amazon.awssdk.services.sqs.model.Message)} from Spring
Messaging message object
Message.MessagingMessageConverter implementation for converting SQS
Message instances to Spring Messaging Message instances.Sqs-specific synchronous messaging operations for Standard and Fifo queues.
Properties related to AWS SQS.
Options for receiving messages from SQS queues, with a method chaining API.
Options for sending messages to SQS queues, with a method chaining API.
Builder interface for creating a
SqsTemplate instance.Sqs specific options for the
SqsTemplate.SQS parameters added to
SendResult objects as additional information.Annotation for a SQS test that focuses only on SQS-based components.
TestContextBootstrapper for @SqsTest support.TypeExcludeFilter for @SqsTest.A
ContainerComponentFactory implementation for Standard SQS queues.AbstractSqsMessageSource implementation for standard queues.Static
AwsRegionProvider implementation that can used to statically configure a region.Properties related to AWS Sts Credentials.
Enables a class to receive a container managed
TaskExecutor.Acknowledgement modes to be used by a
MessageReceivingOperations
implementation.Resolves topic ARN by name.
Implementation of
AbstractMessageChannel which is used for converting and sending messages via
SnsClient to SNS.Thrown when
TopicsListingTopicArnResolver cannot determine ARN based on topicName.Basic implementation for resolving ARN from topicName.
Creates
TransferManagerS3OutputStream.Exception thrown when an executor is provided with an unsupported
ThreadFactory.Thrown when uploading to S3 fails.
Visibility interface that can be injected as parameter into a listener method.
HandlerMethodArgumentResolver for Visibility method parameters.