Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
S
- S3FileInfo - Class in org.springframework.integration.aws.support
-
An Amazon S3
FileInfo
implementation. - S3FileInfo(S3Object) - Constructor for class org.springframework.integration.aws.support.S3FileInfo
- S3InboundFileSynchronizer - Class in org.springframework.integration.aws.inbound
-
An implementation of
AbstractInboundFileSynchronizer
for Amazon S3. - S3InboundFileSynchronizer() - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
- S3InboundFileSynchronizer(SessionFactory<S3Object>) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
-
Create a synchronizer with the
SessionFactory
used to acquireSession
instances. - S3InboundFileSynchronizer(S3Client) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
- S3InboundFileSynchronizingMessageSource - Class in org.springframework.integration.aws.inbound
-
A
MessageSource
implementation for the Amazon S3. - S3InboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<S3Object>) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizingMessageSource
- S3InboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<S3Object>, Comparator<File>) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizingMessageSource
- S3MessageHandler - Class in org.springframework.integration.aws.outbound
-
The
AbstractReplyProducingMessageHandler
implementation for the Amazon S3 services. - S3MessageHandler(S3AsyncClient, String) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3AsyncClient, String, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3AsyncClient, Expression) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3AsyncClient, Expression, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3TransferManager, String) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3TransferManager, String, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3TransferManager, Expression) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler(S3TransferManager, Expression, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
- S3MessageHandler.Command - Enum Class in org.springframework.integration.aws.outbound
-
The
S3MessageHandler
mode. - S3PersistentAcceptOnceFileListFilter - Class in org.springframework.integration.aws.support.filters
-
Persistent file list filter using the server's file timestamp to detect if we've already 'seen' this file.
- S3PersistentAcceptOnceFileListFilter(ConcurrentMetadataStore, String) - Constructor for class org.springframework.integration.aws.support.filters.S3PersistentAcceptOnceFileListFilter
- S3RegexPatternFileListFilter - Class in org.springframework.integration.aws.support.filters
-
Implementation of
AbstractRegexPatternFileListFilter
for Amazon S3. - S3RegexPatternFileListFilter(String) - Constructor for class org.springframework.integration.aws.support.filters.S3RegexPatternFileListFilter
- S3RegexPatternFileListFilter(Pattern) - Constructor for class org.springframework.integration.aws.support.filters.S3RegexPatternFileListFilter
- S3RemoteFileTemplate - Class in org.springframework.integration.aws.support
-
An Amazon S3 specific
RemoteFileTemplate
extension. - S3RemoteFileTemplate() - Constructor for class org.springframework.integration.aws.support.S3RemoteFileTemplate
- S3RemoteFileTemplate(SessionFactory<S3Object>) - Constructor for class org.springframework.integration.aws.support.S3RemoteFileTemplate
-
Construct a
RemoteFileTemplate
with the supplied session factory. - S3RemoteFileTemplate(S3Client) - Constructor for class org.springframework.integration.aws.support.S3RemoteFileTemplate
- S3Session - Class in org.springframework.integration.aws.support
-
An Amazon S3
Session
implementation. - S3Session(S3Client) - Constructor for class org.springframework.integration.aws.support.S3Session
- S3SessionFactory - Class in org.springframework.integration.aws.support
-
An Amazon S3 specific
SessionFactory
implementation. - S3SessionFactory() - Constructor for class org.springframework.integration.aws.support.S3SessionFactory
- S3SessionFactory(S3Client) - Constructor for class org.springframework.integration.aws.support.S3SessionFactory
- S3SimplePatternFileListFilter - Class in org.springframework.integration.aws.support.filters
-
Implementation of
AbstractSimplePatternFileListFilter
for Amazon S3. - S3SimplePatternFileListFilter(String) - Constructor for class org.springframework.integration.aws.support.filters.S3SimplePatternFileListFilter
- S3StreamingMessageSource - Class in org.springframework.integration.aws.inbound
-
A
AbstractRemoteFileStreamingMessageSource
implementation for the Amazon S3. - S3StreamingMessageSource(RemoteFileTemplate<S3Object>) - Constructor for class org.springframework.integration.aws.inbound.S3StreamingMessageSource
- S3StreamingMessageSource(RemoteFileTemplate<S3Object>, Comparator<S3Object>) - Constructor for class org.springframework.integration.aws.inbound.S3StreamingMessageSource
- sdkFields() - Method in class org.springframework.integration.aws.support.UserRecordResponse
- send(Object) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- SEQUENCE_NUMBER - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_sequenceNumber" header for sending data to SQS/Kinesis.
- sequenceNumber() - Method in class org.springframework.integration.aws.support.UserRecordResponse
- SERVICE_RESULT - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_serviceResult" header represents a
AmazonWebServiceResult
. - setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setBackPressureThreshold(long) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Configure maximum records in flight for handling backpressure.
- setBillingMode(BillingMode) - Method in class org.springframework.integration.aws.lock.DynamoDbLockRepository
- setBillingMode(BillingMode) - Method in class org.springframework.integration.aws.metadata.DynamoDbMetadataStore
- setBindSourceRecord(boolean) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Set to true to bind the source consumer record in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBindSourceRecord(boolean) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Set to true to bind the source consumer record in the header named
IntegrationMessageHeaderAccessor.SOURCE_DATA
. - setBodyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
The
Expression
to produce the SNS notification message. - setCheckpointMode(CheckpointMode) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setCheckpointMode(CheckpointMode) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setCheckpointsInterval(long) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Sets the interval between 2 checkpoints.
- setCheckpointsInterval(long) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Sets the interval between 2 checkpoints.
- setCheckpointStore(ConcurrentMetadataStore) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setCommand(S3MessageHandler.Command) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
Specify a
S3MessageHandler.Command
to perform againstS3TransferManager
. - setCommandExpression(Expression) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
The SpEL expression to evaluate the command to perform on
S3TransferManager
:upload
,download
orcopy
. - setConcurrency(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
The maximum number of concurrent
KinesisMessageDrivenChannelAdapter.ConsumerInvoker
s running. - setConsumerBackoff(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setConsumerBackoff(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setConsumerExecutor(Executor) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setConsumerGroup(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setConsumerGroup(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setConverter(Converter<byte[], Object>) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Specify a
Converter
to deserialize thebyte[]
from record's body. - setConverter(Converter<byte[], Object>) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Specify a
Converter
to deserialize thebyte[]
from record's body. - setConverter(Converter<Object, byte[]>) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
Deprecated.
- setConverter(Converter<Object, byte[]>) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Deprecated.
- setCoordinatorConfigCustomizer(Consumer<CoordinatorConfig>) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Set a
Consumer
to configure aCoordinatorConfig
. - setCreateTableDelay(int) - Method in class org.springframework.integration.aws.metadata.DynamoDbMetadataStore
- setCreateTableRetries(int) - Method in class org.springframework.integration.aws.metadata.DynamoDbMetadataStore
- setDelay(int) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setDelayExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setDelayExpressionString(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setDescribeStreamBackoff(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setDescribeStreamRetries(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setDestinationBucketExpression(Expression) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
The SpEL expression to evaluate the target S3 bucket for copy operation.
- setDestinationKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
The SpEL expression to evaluate the target S3 key for copy operation.
- setDispatcherExecutor(Executor) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setEmbeddedHeadersMapper(InboundMessageMapper<byte[]>) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Specify an
InboundMessageMapper
to extract message headers embedded into the record data. - setEmbeddedHeadersMapper(InboundMessageMapper<byte[]>) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Specify an
InboundMessageMapper
to extract message headers embedded into the record data. - setEmbeddedHeadersMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
Specify a
OutboundMessageMapper
for embedding message headers into the record data together with payload. - setEmbeddedHeadersMapper(OutboundMessageMapper<byte[]>) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Specify a
OutboundMessageMapper
for embedding message headers into the record data together with payload. - setEmptyRecordList(boolean) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Whether to return an empty record list from consumer to the processor.
- setEndpoint(String) - Method in class org.springframework.integration.aws.support.S3Session
- setEndpoint(String) - Method in class org.springframework.integration.aws.support.S3SessionFactory
- setExecutor(TaskExecutor) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setExplicitHashKey(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setExplicitHashKey(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setExplicitHashKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setExplicitHashKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setExplicitHashKeyExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setExplicitHashKeyExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setExtractReplyPayload(boolean) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setFanOut(boolean) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Specify a retrieval strategy: fan-out (true; default) or polling (false).
- setFlushDuration(Duration) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Configure a
Duration
how often to call aKinesisProducer.flush()
. - setGlueSchema(Schema) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Set a
Schema
to add into aUserRecord
built from the request message. - setGlueSchemaExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Set a SpEL expression for
Schema
to add into aUserRecord
built from the request message. - setGlueSchemaExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Set a SpEL expression for
Schema
to add into aUserRecord
built from the request message. - setGlueSchemaRegistryDeserializer(GlueSchemaRegistryDeserializer) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setGracefulShutdownTimeout(long) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
The timeout for
Scheduler.startGracefulShutdown()
. - setHandleNotificationStatus(boolean) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setHeaderExpressions(Map<String, Expression>) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setHeaderMapper(HeaderMapper<H>) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
-
Specify a
HeaderMapper
to map outbound headers. - setHeaderMapper(HeaderMapper<Void>) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
Unsupported operation.
- setHeaderMapper(HeaderMapper<Void>) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Unsupported operation.
- setHeaderMapper(HeaderMapper<HttpHeaders>) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setIdleBetweenPolls(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
The sleep interval in milliseconds used in the main loop between shards polling cycles.
- setIdleBetweenTries(Duration) - Method in class org.springframework.integration.aws.lock.DynamoDbLockRegistry
-
Specify a
Duration
to sleep between lock record insert/update attempts. - setIteratorType(ShardIteratorType) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
- setKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
The SpEL expression to evaluate S3 object key at runtime against
requestMessage
. - setLeaseDuration(Duration) - Method in class org.springframework.integration.aws.lock.DynamoDbLockRepository
-
How long to hold the item after last update.
- setLeaseManagementConfigCustomizer(Consumer<LeaseManagementConfig>) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Set a
Consumer
to configure aLeaseManagementConfig
. - setLeaseTableName(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Set a name of the DynamoDB table name for leases.
- setLifecycleConfigCustomizer(Consumer<LifecycleConfig>) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Set a
Consumer
to configure aLifecycleConfig
. - setListenerMode(ListenerMode) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setListenerMode(ListenerMode) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setLockRegistry(LockRegistry) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Specify a
LockRegistry
for exclusive access to provided streams. - setLockRenewalTimeout(long) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Configure a timeout in milliseconds to wait for lock on shard renewal.
- setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setMessageConverter(MessageConverter) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
Configure a
MessageConverter
for converting payload tobyte[]
for Kinesis record. - setMessageConverter(MessageConverter) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
-
Configure a
MessageConverter
for converting payload tobyte[]
for Kinesis record. - setMessageConverter(MessageConverter) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMessageConverters(List<HttpMessageConverter<?>>) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setMessageDeduplicationId(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMessageDeduplicationIdExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
The
Expression
to determine the deduplication ID for this message. - setMessageDeduplicationIdExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMessageDeduplicationIdExpressionString(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMessageGroupId(String) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
A fixed message-group ID to be set for messages sent to an SNS FIFO topic from this handler.
- setMessageGroupId(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMessageGroupIdExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
The
Expression
to determine the message group for messages sent to an SNS FIFO topic from this handler. - setMessageGroupIdExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMessageGroupIdExpressionString(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setMetricsConfigCustomizer(Consumer<MetricsConfig>) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Set a
Consumer
to configure aMetricsConfig
. - setMetricsLevel(MetricsLevel) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Specify a metrics level to emit.
- setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setOutboundHeaderNames(String...) - Method in class org.springframework.integration.aws.support.AbstractMessageAttributesHeaderMapper
-
Provide the header names that should be mapped to a AWS request object attributes (for outbound adapters) from a Spring Integration Message's headers.
- setOwner(String) - Method in class org.springframework.integration.aws.lock.DynamoDbLockRepository
-
Specify a custom client id (owner) for locks in DB.
- setPartitionKey(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setPartitionKey(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setPartitionKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setPartitionKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setPartitionKeyExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setPartitionKeyExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setPayloadExpression(Expression) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setPollingIdleTime(long) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
The idle timeout between polls when using
PollingConfig
. - setPollingMaxRecords(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
The number of records to poll from Kinesis when using
PollingConfig
. - setQueue(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setQueueExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setQueueExpressionString(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
- setQueueNotFoundStrategy(QueueNotFoundStrategy) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
-
Set a
QueueNotFoundStrategy
; defaults toQueueNotFoundStrategy.FAIL
. - setReadCapacity(long) - Method in class org.springframework.integration.aws.lock.DynamoDbLockRepository
- setReadCapacity(long) - Method in class org.springframework.integration.aws.metadata.DynamoDbMetadataStore
- setRecordsLimit(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
The maximum record to poll per on get-records request.
- setRequestMapping(RequestMapping) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setRequestPayloadTypeClass(Class<?>) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setReset(boolean) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
- setSendTimeout(long) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
- setSendTimeoutExpression(Expression) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
- setSendTimeoutExpressionString(String) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
- setSequenceNumber(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
- setSequenceNumberExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setSequenceNumberExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setSequenceNumberExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setSequenceNumberExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setShard(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
- setShardListFilter(Function<List<Shard>, List<Shard>>) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Specify a
Function<List<Shard>, List<Shard>>
to filter the shards which will be read from. - setSqsContainerOptions(SqsContainerOptions) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
- setStartTimeout(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setStatusCodeExpression(Expression) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- setStream(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
- setStream(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setStream(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setStreamExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setStreamExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setStreamExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
- setStreamExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- setStreamInitialSequence(KinesisShardOffset) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- setStreamInitialSequence(InitialPositionInStreamExtended) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
- setSubject(String) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
- setSubjectExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
- setTimestamp(Instant) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
- setTimeToLive(int) - Method in class org.springframework.integration.aws.metadata.DynamoDbMetadataStore
-
Configure a period in seconds for items expiration.
- setTopicArn(String) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
- setTopicArnExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
- setTopicArnResolver(TopicArnResolver) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
Provide a custom
TopicArnResolver
; defaults toSnsAsyncTopicArnResolver
. - setUploadMetadataProvider(BiConsumer<PutObjectRequest.Builder, Message<?>>) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
Specify an
BiConsumer
callback to populate the metadata for upload operation, e.g. - setWorkerId(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KclMessageDrivenChannelAdapter
-
Sets the worker identifier used to distinguish different workers/processes of a Kinesis application.
- setWriteCapacity(long) - Method in class org.springframework.integration.aws.lock.DynamoDbLockRepository
- setWriteCapacity(long) - Method in class org.springframework.integration.aws.metadata.DynamoDbMetadataStore
- SHARD - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_shard" header to represent Kinesis shardId.
- shardId() - Method in class org.springframework.integration.aws.support.UserRecordResponse
- shouldCopyRequestHeaders() - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
- SNS_MESSAGE_TYPE - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_snsMessageType" header for SNS message type.
- SnsAsyncTopicArnResolver - Class in org.springframework.integration.aws.support
-
A
TopicArnResolver
implementation to determine topic ARN by name against anSnsAsyncClient
. - SnsAsyncTopicArnResolver(SnsAsyncClient) - Constructor for class org.springframework.integration.aws.support.SnsAsyncTopicArnResolver
- SnsBodyBuilder - Class in org.springframework.integration.aws.support
-
A utility class to simplify an SNS Message body building.
- SnsHeaderMapper - Class in org.springframework.integration.aws.support
-
The
AbstractMessageAttributesHeaderMapper
implementation for the mapping from headers to SNS message attributes. - SnsHeaderMapper() - Constructor for class org.springframework.integration.aws.support.SnsHeaderMapper
- SnsInboundChannelAdapter - Class in org.springframework.integration.aws.inbound
-
The
HttpRequestHandlingMessagingGateway
extension for the Amazon WS SNS HTTP(S) endpoints. - SnsInboundChannelAdapter(SnsClient, String...) - Constructor for class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
- SnsMessageHandler - Class in org.springframework.integration.aws.outbound
-
The
AbstractAwsMessageHandler
implementation to send SNS Notifications (SnsAsyncClient.publish(PublishRequest)
) to the providedtopicArn
(or evaluated at runtime againstMessage
). - SnsMessageHandler(SnsAsyncClient) - Constructor for class org.springframework.integration.aws.outbound.SnsMessageHandler
- SqsHeaderMapper - Class in org.springframework.integration.aws.support
-
The
AbstractMessageAttributesHeaderMapper
implementation for the mapping from headers to SQS message attributes. - SqsHeaderMapper() - Constructor for class org.springframework.integration.aws.support.SqsHeaderMapper
- SqsMessageDrivenChannelAdapter - Class in org.springframework.integration.aws.inbound
-
The
MessageProducerSupport
implementation for the Amazon SQSreceiveMessage
. - SqsMessageDrivenChannelAdapter(SqsAsyncClient, String...) - Constructor for class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
- SqsMessageHandler - Class in org.springframework.integration.aws.outbound
-
The
AbstractMessageHandler
implementation for the Amazon SQSsendMessage
. - SqsMessageHandler(SqsAsyncClient) - Constructor for class org.springframework.integration.aws.outbound.SqsMessageHandler
- start() - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- startConsumer(String, String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- stop() - Method in class org.springframework.integration.aws.outbound.KplMessageHandler
- stopConsumer(String, String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
- STREAM - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_stream" header for sending data to Kinesis.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
KinesisMessageHandler.setMessageConverter(org.springframework.messaging.converter.MessageConverter)