- S3_REF - Static variable in class org.springframework.integration.aws.config.xml.AwsParserUtils
-
The 's3' reference attribute name.
- S3FileInfo - Class in org.springframework.integration.aws.support
-
An Amazon S3 FileInfo
implementation.
- S3FileInfo(S3ObjectSummary) - Constructor for class org.springframework.integration.aws.support.S3FileInfo
-
- S3InboundChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
Parser for the AWS 's3-inbound-channel-adapter' element.
- S3InboundChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.S3InboundChannelAdapterParser
-
- 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(AmazonS3) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
-
- S3InboundFileSynchronizer(SessionFactory<S3ObjectSummary>) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
-
Create a synchronizer with the SessionFactory
used to acquire Session
instances.
- S3InboundFileSynchronizingMessageSource - Class in org.springframework.integration.aws.inbound
-
A MessageSource
implementation for the Amazon S3.
- S3InboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<S3ObjectSummary>) - Constructor for class org.springframework.integration.aws.inbound.S3InboundFileSynchronizingMessageSource
-
- S3InboundFileSynchronizingMessageSource(AbstractInboundFileSynchronizer<S3ObjectSummary>, 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(AmazonS3, String) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(AmazonS3, Expression) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(AmazonS3, String, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(AmazonS3, Expression, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(TransferManager, String) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(TransferManager, Expression) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(TransferManager, String, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler(TransferManager, Expression, boolean) - Constructor for class org.springframework.integration.aws.outbound.S3MessageHandler
-
- S3MessageHandler.Command - Enum in org.springframework.integration.aws.outbound
-
- S3MessageHandler.UploadMetadataProvider - Interface in org.springframework.integration.aws.outbound
-
The callback to populate an ObjectMetadata
for upload operation.
- S3OutboundChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
The parser for the <int-aws:s3-outbound-channel-adapter>
.
- S3OutboundChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.S3OutboundChannelAdapterParser
-
- S3OutboundGatewayParser - Class in org.springframework.integration.aws.config.xml
-
The parser for the <int-aws:s3-outbound-gateway>
.
- S3OutboundGatewayParser() - Constructor for class org.springframework.integration.aws.config.xml.S3OutboundGatewayParser
-
- 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(AmazonS3) - Constructor for class org.springframework.integration.aws.support.S3RemoteFileTemplate
-
- S3RemoteFileTemplate(SessionFactory<S3ObjectSummary>) - Constructor for class org.springframework.integration.aws.support.S3RemoteFileTemplate
-
Construct a RemoteFileTemplate
with the supplied session factory.
- S3Session - Class in org.springframework.integration.aws.support
-
An Amazon S3 Session
implementation.
- S3Session(AmazonS3) - Constructor for class org.springframework.integration.aws.support.S3Session
-
- S3Session(AmazonS3, ResourceIdResolver) - 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(AmazonS3) - Constructor for class org.springframework.integration.aws.support.S3SessionFactory
-
- S3SessionFactory(AmazonS3, ResourceIdResolver) - 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
-
- S3StreamingInboundChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
Parser for the AWS 's3-inbound-streaming-channel-adapter' element.
- S3StreamingInboundChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.S3StreamingInboundChannelAdapterParser
-
- S3StreamingMessageSource - Class in org.springframework.integration.aws.inbound
-
A AbstractRemoteFileStreamingMessageSource
implementation for the Amazon S3.
- S3StreamingMessageSource(RemoteFileTemplate<S3ObjectSummary>) - Constructor for class org.springframework.integration.aws.inbound.S3StreamingMessageSource
-
- S3StreamingMessageSource(RemoteFileTemplate<S3ObjectSummary>, Comparator<AbstractFileInfo<S3ObjectSummary>>) - Constructor for class org.springframework.integration.aws.inbound.S3StreamingMessageSource
-
- 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.
- SERVICE_RESULT - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_serviceResult" header represents a AmazonWebServiceResult
.
- setAsyncHandler(AsyncHandler<? extends AmazonWebServiceRequest, ?>) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
-
- setAutoStartup(boolean) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- 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.KinesisMessageDrivenChannelAdapter
-
- setCheckpointStore(MetadataStore) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
- setCommand(S3MessageHandler.Command) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
- setCommandExpression(Expression) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
The SpEL expression to evaluate the command to perform on TransferManager
: upload
,
download
or copy
.
- setConcurrency(int) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
The maximum number of concurrent ConsumerInvoker
s running.
- 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.KinesisMessageDrivenChannelAdapter
-
- setConverter(Converter<byte[], Object>) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
Specify a Converter
to deserialize the byte[]
from record's body.
- setConverter(Converter<Object, byte[]>) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
Specify a Converter
to serialize payload
to the byte[]
if that isn't byte[]
already.
- 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.
- setDestinationResolver(DestinationResolver<String>) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- setDispatcherExecutor(Executor) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
- setErrorMessageStrategy(ErrorMessageStrategy) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
-
- setExplicitHashKey(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setExplicitHashKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setExplicitHashKeyExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setExtractReplyPayload(boolean) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
-
- setFailureChannel(MessageChannel) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
-
Set the failure channel.
- setFailureChannelName(String) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
-
Set the failure channel name.
- setFilter(FileListFilter<S3ObjectSummary>) - Method in class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
-
- 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<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.
- 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
.
- setListenerMode(ListenerMode) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
- setMaxNumberOfMessages(Integer) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- setMergeWithDefaultConverters(boolean) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
-
- 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.SqsMessageHandler
-
- setMessageDeduplicationIdExpressionString(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
-
- setMessageDeletionPolicy(SqsMessageDeletionPolicy) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- setMessageGroupId(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
-
- setMessageGroupIdExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
-
- setMessageGroupIdExpressionString(String) - Method in class org.springframework.integration.aws.outbound.SqsMessageHandler
-
- setMultipartResolver(MultipartResolver) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
-
- setObjectAclExpression(Expression) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
The SpEL expression to evaluate S3 object ACL at runtime against requestMessage
for the upload
operation.
- setPartitionKey(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setPartitionKeyExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setPartitionKeyExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setPayloadExpression(Expression) - Method in class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
-
- setProgressListener(S3ProgressListener) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
Specify a S3ProgressListener
for upload and download operations.
- 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
-
- setQueueStopTimeout(long) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- 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.
- setRemoteDirectoryExpression(Expression) - Method in class org.springframework.integration.aws.inbound.S3InboundFileSynchronizer
-
- 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
-
- setResourceIdResolver(ResourceIdResolver) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- setResourceIdResolver(ResourceIdResolver) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
Specify a ResourceIdResolver
to resolve logical bucket names to physical resource ids.
- setResourceIdResolver(ResourceIdResolver) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
Specify a ResourceIdResolver
to resolve logical topic names to physical resource ids.
- 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
-
- setSequenceNumberExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setShard(String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
-
- 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
-
- setStreamExpression(Expression) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setStreamExpressionString(String) - Method in class org.springframework.integration.aws.outbound.KinesisMessageHandler
-
- setStreamInitialSequence(KinesisShardOffset) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
- setSubject(String) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
- setSubjectExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
- setSync(boolean) - Method in class org.springframework.integration.aws.outbound.AbstractAwsMessageHandler
-
- setTaskExecutor(AsyncTaskExecutor) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- setTimestamp(Date) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisShardOffset
-
- setTopicArn(String) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
- setTopicArnExpression(Expression) - Method in class org.springframework.integration.aws.outbound.SnsMessageHandler
-
- setUploadMetadataProvider(S3MessageHandler.UploadMetadataProvider) - Method in class org.springframework.integration.aws.outbound.S3MessageHandler
-
Specify an ObjectMetadata
callback to populate the metadata for upload operation,
e.g.
- setVisibilityTimeout(Integer) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- setWaitTimeOut(Integer) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- 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.
- SNS_MESSAGE_TYPE - Static variable in class org.springframework.integration.aws.support.AwsHeaders
-
The "aws_snsMessageType" header for SNS message type.
- SNS_REF - Static variable in class org.springframework.integration.aws.config.xml.AwsParserUtils
-
The 'sns' reference attribute name.
- SnsBodyBuilder - Class in org.springframework.integration.aws.support
-
An utility class to simplify an SNS Message body building.
- SnsInboundChannelAdapter - Class in org.springframework.integration.aws.inbound
-
The HttpRequestHandlingMessagingGateway
extension for the Amazon WS SNS HTTP(S) endpoints.
- SnsInboundChannelAdapter(AmazonSNS, String...) - Constructor for class org.springframework.integration.aws.inbound.SnsInboundChannelAdapter
-
- SnsInboundChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
The parser for the <int-aws:sns-inbound-channel-adapter>
.
- SnsInboundChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.SnsInboundChannelAdapterParser
-
- SnsMessageHandler - Class in org.springframework.integration.aws.outbound
-
The
AbstractAwsMessageHandler
implementation to send SNS Notifications
(
AmazonSNSAsync.publishAsync(PublishRequest)
) to the provided
topicArn
(or evaluated at runtime against
Message
).
- SnsMessageHandler(AmazonSNSAsync) - Constructor for class org.springframework.integration.aws.outbound.SnsMessageHandler
-
- SnsOutboundChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
The parser for the <int-aws:sns-outbound-channel-adapter>
.
- SnsOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.SnsOutboundChannelAdapterParser
-
- SQS_REF - Static variable in class org.springframework.integration.aws.config.xml.AwsParserUtils
-
The 'sqs' reference attribute name.
- SqsMessageDrivenChannelAdapter - Class in org.springframework.integration.aws.inbound
-
The MessageProducerSupport
implementation for the Amazon SQS receiveMessage
.
- SqsMessageDrivenChannelAdapter(AmazonSQSAsync, String...) - Constructor for class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- SqsMessageDrivenChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
The parser for the <int-aws:sqs-message-driven-channel-adapter>
.
- SqsMessageDrivenChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.SqsMessageDrivenChannelAdapterParser
-
- SqsMessageHandler - Class in org.springframework.integration.aws.outbound
-
The AbstractMessageHandler
implementation for the Amazon SQS sendMessage
.
- SqsMessageHandler(AmazonSQSAsync) - Constructor for class org.springframework.integration.aws.outbound.SqsMessageHandler
-
- SqsMessageHandler(AmazonSQSAsync, ResourceIdResolver) - Constructor for class org.springframework.integration.aws.outbound.SqsMessageHandler
-
- SqsOutboundChannelAdapterParser - Class in org.springframework.integration.aws.config.xml
-
The parser for the <int-aws:sqs-outbound-channel-adapter>
.
- SqsOutboundChannelAdapterParser() - Constructor for class org.springframework.integration.aws.config.xml.SqsOutboundChannelAdapterParser
-
- start(String) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- startConsumer(String, String) - Method in class org.springframework.integration.aws.inbound.kinesis.KinesisMessageDrivenChannelAdapter
-
- stop(String) - Method in class org.springframework.integration.aws.inbound.SqsMessageDrivenChannelAdapter
-
- 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.