Index

A B C D E F G H I J L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values

A

ACK_AUTO - Enum constant in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
 
ACK_RANGE - Enum constant in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
 
ACK_UNORDERED - Enum constant in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
 
acknowledge() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Acknowledges message(s).
acknowledge(SQSMessage) - Method in interface com.amazon.sqs.javamessaging.acknowledge.Acknowledger
Generic Acknowledge method.
acknowledge(SQSMessage) - Method in class com.amazon.sqs.javamessaging.acknowledge.AutoAcknowledger
Acknowledges the consumed message via calling deleteMessage
acknowledge(SQSMessage) - Method in class com.amazon.sqs.javamessaging.acknowledge.RangedAcknowledger
Acknowledges all the consumed messages as well as the previously consumed messages on the session via calling deleteMessageBatch until all the messages are deleted.
acknowledge(SQSMessage) - Method in class com.amazon.sqs.javamessaging.acknowledge.UnorderedAcknowledger
Acknowledges the consumed message via calling deleteMessage.
AcknowledgeMode - Enum Class in com.amazon.sqs.javamessaging.acknowledge
Specifies the different possible modes of acknowledgment: In ACK_AUTO mode, every time the user receives a message, it is acknowledged automatically.
Acknowledger - Interface in com.amazon.sqs.javamessaging.acknowledge
 
action(String, List<String>) - Method in class com.amazon.sqs.javamessaging.acknowledge.BulkSQSOperation
Action call block.
action(String, List<String>) - Method in class com.amazon.sqs.javamessaging.acknowledge.NegativeAcknowledger
Action call block for negative acknowledge for the list of receipt handles.
action(String, List<String>) - Method in class com.amazon.sqs.javamessaging.acknowledge.RangedAcknowledger
Acknowledges up to 10 messages via calling deleteMessageBatch.
ALL - Static variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
AmazonSQSMessagingClientWrapper - Class in com.amazon.sqs.javamessaging
This is a JMS Wrapper of SqsClient.
AmazonSQSMessagingClientWrapper(SqsClient) - Constructor for class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
 
AmazonSQSMessagingClientWrapper(SqsClient, AwsCredentialsProvider) - Constructor for class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
 
APPROXIMATE_RECEIVE_COUNT - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
AutoAcknowledger - Class in com.amazon.sqs.javamessaging.acknowledge
Used by session to automatically acknowledge a client's receipt of a message either when the session has successfully returned from a call to receive or when the message listener the session has called to process the message successfully returns.
AutoAcknowledger(AmazonSQSMessagingClientWrapper, SQSSession) - Constructor for class com.amazon.sqs.javamessaging.acknowledge.AutoAcknowledger
 

B

backoffStrategy - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
AWS SQS SDK with default backup strategy already re-tries 3 times exponentially.
BOOLEAN - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
bulkAction(ArrayDeque<SQSMessageConsumerPrefetch.MessageManager>, String) - Method in class com.amazon.sqs.javamessaging.acknowledge.NegativeAcknowledger
Bulk action for negative acknowledge on the list of messages of a specific queue.
bulkAction(List<SQSMessageIdentifier>, int) - Method in class com.amazon.sqs.javamessaging.acknowledge.BulkSQSOperation
Bulk action on list of message identifiers up to the provided index
BulkSQSOperation - Class in com.amazon.sqs.javamessaging.acknowledge
This is used by different acknowledgers that requires partitioning of the list, and execute actions on the partitions
BulkSQSOperation() - Constructor for class com.amazon.sqs.javamessaging.acknowledge.BulkSQSOperation
 
BYTE - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
BYTE_MESSAGE_TYPE - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 

C

callbackQueue - Variable in class com.amazon.sqs.javamessaging.SQSSessionCallbackScheduler
 
changeMessageVisibility(ChangeMessageVisibilityRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls changeMessageVisibility and wraps SdkException.
changeMessageVisibilityBatch(ChangeMessageVisibilityBatchRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls changeMessageVisibilityBatch and wraps SdkException.
checkBodyWritePermissions() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
checkClosed() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Checks if the connection close is already completed.
checkClosed() - Method in class com.amazon.sqs.javamessaging.SQSSession
Check if session is closed.
checkClosing() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Checks if the connection close is in-progress or already completed.
checkClosing() - Method in class com.amazon.sqs.javamessaging.SQSSession
Check if session is closed or closing.
checkPropertyWritePermissions() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
clearBody() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
When the message is first created, and when clearBody is called, the body of the message is in write-only mode.
clearBody() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Clears out the message body.
clearBody() - Method in class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Sets the message body to write mode, and sets the object body to null
clearBody() - Method in class com.amazon.sqs.javamessaging.message.SQSTextMessage
Sets the message body to write mode, and sets the text to null
clearProperties() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Clears a message's properties and set the write permissions for properties.
close() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Closes the connection.
close() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
Closes the message consumer.
close() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Closes the message producer.
close() - Method in class com.amazon.sqs.javamessaging.SQSSession
Closes the session.
closed - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumer
 
closed - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
States of the prefetch thread
com.amazon.sqs.javamessaging - package com.amazon.sqs.javamessaging
 
com.amazon.sqs.javamessaging.acknowledge - package com.amazon.sqs.javamessaging.acknowledge
 
com.amazon.sqs.javamessaging.message - package com.amazon.sqs.javamessaging.message
 
com.amazon.sqs.javamessaging.util - package com.amazon.sqs.javamessaging.util
 
commit() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
CONNECTION_METADATA - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
convert(Object, Class<T>) - Static method in class com.amazon.sqs.javamessaging.message.SQSMessage.TypeConversionSupport
 
convertExceptionToJMSException(Exception) - Static method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
convertExceptionToMessageFormatException(Exception) - Static method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
convertToJMSMessage(Message) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Convert the return SQS message into JMS message
createAcknowledger(AmazonSQSMessagingClientWrapper, SQSSession) - Method in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
Creates the acknowledger associated with the session, which will be used to acknowledge the delivered messages on consumers of the session.
createBrowser(Queue) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createBrowser(Queue, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createBytesMessage() - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a BytesMessage.
createConnection() - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createConnection(String, String) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createConnection(AwsCredentials) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createConnection(AwsCredentialsProvider) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
This method is not supported.
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
This method is not supported.
createConsumer(Destination) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a MessageConsumer for the specified destination.
createConsumer(Destination, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a MessageConsumer for the specified destination.
createConsumer(Destination, String, boolean) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a MessageConsumer for the specified destination.
createContext() - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createContext(int) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createContext(String, String) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createContext(String, String, int) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
This method is not supported.
createDurableConsumer(Topic, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
 
createDurableConsumer(Topic, String, String, boolean) - Method in class com.amazon.sqs.javamessaging.SQSSession
 
createDurableSubscriber(Topic, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createDurableSubscriber(Topic, String, String, boolean) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createMapMessage() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createMessage() - Method in class com.amazon.sqs.javamessaging.SQSSession
According to JMS specification, a message can be sent with only headers without any payload, SQS does not support messages with empty payload.
createObjectMessage() - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a ObjectMessage.
createObjectMessage(Serializable) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates an initialized ObjectMessage.
createProducer(Destination) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a MessageProducer for the specified destination.
createQueue(String) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls createQueue to create the queue with the default queue attributes, and wraps SdkException
createQueue(String) - Method in class com.amazon.sqs.javamessaging.SQSSession
This does not create SQS Queue.
createQueue(String, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
This does not create SQS Queue.
createQueue(CreateQueueRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls createQueue to create the queue with the provided queue attributes if any, and wraps SdkException
createQueueConnection() - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createQueueConnection(String, String) - Method in class com.amazon.sqs.javamessaging.SQSConnectionFactory
 
createQueueSession(boolean, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
Creates a QueueSession
createReceiver(Queue) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a QueueReceiver for the specified queue.
createReceiver(Queue, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a QueueReceiver for the specified queue.
createSender(Queue) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a QueueSender for the specified queue.
createSession() - Method in class com.amazon.sqs.javamessaging.SQSConnection
 
createSession(boolean, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
Creates a Session
createSession(int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
 
createSharedConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
 
createSharedConsumer(Topic, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
 
createSharedConsumer(Topic, String, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
 
createSharedDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class com.amazon.sqs.javamessaging.SQSConnection
 
createSharedDurableConsumer(Topic, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
 
createSharedDurableConsumer(Topic, String, String) - Method in class com.amazon.sqs.javamessaging.SQSSession
 
createStreamMessage() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createTemporaryQueue() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createTemporaryTopic() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
createTextMessage() - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates a TextMessage.
createTextMessage(String) - Method in class com.amazon.sqs.javamessaging.SQSSession
Creates an initialized TextMessage.
createTopic(String) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.

D

delayBeforeNextRetry(int) - Method in class com.amazon.sqs.javamessaging.util.ExponentialBackoffStrategy
Returns the delay before the next attempt.
deleteMessage(DeleteMessageRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls deleteMessage and wraps SdkException.
deleteMessageBatch(DeleteMessageBatchRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls deleteMessageBatch and wraps SdkException.
deserialize(String) - Static method in class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Deserialize the String into Serializable object.
deserializePropertyName(String) - Static method in class com.amazon.sqs.javamessaging.util.SQSMessagingClientUtil
Changes everything from underscores Unicode number underscores back to original character, e.g., (_42_attr_42_ -> *attr*).
DOUBLE - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 

E

equals(Object) - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
 
equals(Object) - Method in record class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch.MessageManager
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class com.amazon.sqs.javamessaging.SQSQueueDestination
 
ExponentialBackoffStrategy - Class in com.amazon.sqs.javamessaging.util
Simple exponential back-off strategy, that is used for re-tries on SQS interactions.
ExponentialBackoffStrategy(long, long, long) - Constructor for class com.amazon.sqs.javamessaging.util.ExponentialBackoffStrategy
 

F

FLOAT - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
forgetUnAckMessages() - Method in interface com.amazon.sqs.javamessaging.acknowledge.Acknowledger
Deletes all not acknowledged delivered messages.
forgetUnAckMessages() - Method in class com.amazon.sqs.javamessaging.acknowledge.AutoAcknowledger
AutoAcknowledge doesn't need to do anything in this method.
forgetUnAckMessages() - Method in class com.amazon.sqs.javamessaging.acknowledge.RangedAcknowledger
Clears the list of not acknowledged messages.
forgetUnAckMessages() - Method in class com.amazon.sqs.javamessaging.acknowledge.UnorderedAcknowledger
Clears the list of not acknowledged messages.
fromSQSMessage(SQSMessage) - Static method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
 

G

getAcknowledgeMode() - Method in class com.amazon.sqs.javamessaging.SQSSession
Returns the acknowledge mode of the session.
getAmazonSQSClient() - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
If one uses any other AWS SDK operations other than explicitly listed here, the exceptions thrown by those operations will not be wrapped as JMSException.
getAmazonSQSClient() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Get the AmazonSQSClient used by this connection.
getBody(Class<T>) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getBodyAsBytes() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads the body of message, which can be either the body returned from the the receives message as bytes or the bytes put in bytesOut if it is a sent message.
getBodyLength() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Gets the number of bytes of the message body when the message is in read-only mode.
getBooleanProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the boolean property with the specified name.
getByteProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the byte property with the specified name.
getClientID() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Gets the client identifier for this connection.
getDeliveryDelay() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Gets the minimum length of time in milliseconds that must elapse after a message is sent before the JMS provider may deliver the message to a consumer.
getDeliveryMode() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
getDestination() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Gets the destination associated with this MessageProducer.
getDisableMessageID() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
getDisableMessageTimestamp() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
getDoubleProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the double property with the specified name.
getExceptionListener() - Method in class com.amazon.sqs.javamessaging.SQSConnection
 
getFloatProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the float property with the specified name.
getGroupId() - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
Returns the group id to which the message belongs.
getIntProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the int property with the specified name.
getJMSCorrelationID() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSCorrelationIDAsBytes() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSDeliveryMode() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSDeliveryTime() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSDestination() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Gets the Destination object for this message.
getJMSExpiration() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSMajorVersion() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getJMSMessageID() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Gets the message ID.
getJMSMessagePropertyValue(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the property value with message attribute to object property conversions took place.
getJMSMinorVersion() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getJMSPriority() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSProviderName() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getJMSRedelivered() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSReplyTo() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSTimestamp() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSType() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
getJMSVersion() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getJMSXPropertyNames() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getLongProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the long property with the specified name.
getMessageBody() - Method in class com.amazon.sqs.javamessaging.message.SQSObjectMessage
 
getMessageConsumer() - Method in interface com.amazon.sqs.javamessaging.PrefetchManager
This is used to determine the state of the consumer, when the message listener scheduler is processing the messages.
getMessageConsumer() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
getMessageListener() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
Gets the message consumer's MessageListener.
getMessageListener() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
getMessages(int, int) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Call receiveMessage with the given wait time.
getMessageSelector() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
This method is not supported.
getMessagesWithBackoff(int) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
getMetaData() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Get the metadata for this connection
getNumberOfMessagesToPrefetch() - Method in class com.amazon.sqs.javamessaging.ProviderConfiguration
 
getObject() - Method in class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Gets the Serializable containing this message's body
getObjectProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the Java object property with the specified name.
getOriginalAcknowledgeMode() - Method in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
Returns the acknowledgment mode.
getPriority() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
getPropertyNames() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns an Enumeration of all the property names.
getProviderMajorVersion() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getProviderMinorVersion() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getProviderVersion() - Method in class com.amazon.sqs.javamessaging.SQSConnectionMetaData
 
getQueue() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
Gets the queue destination associated with this queue receiver, where the messages are delivered from.
getQueue() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
 
getQueueName() - Method in class com.amazon.sqs.javamessaging.SQSQueueDestination
Returns the name of this queue.
getQueueUrl() - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
Returns the queueUrl where the message was sent or received from.
getQueueUrl() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Get queueUrl the message came from.
getQueueUrl() - Method in class com.amazon.sqs.javamessaging.SQSQueueDestination
Returns the queueUrl of this queue.
getQueueUrl(String) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Gets the queueUrl of a queue given a queue name.
getQueueUrl(String, String) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Gets the queueUrl of a queue given a queue name owned by the provided accountId.
getQueueUrl(GetQueueUrlRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls getQueueUrl and wraps SdkException
getReceiptHandle() - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
Returns the receipt handle returned after the delivery of the message from SQS.
getReceiptHandle() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Get SQS Message receiptHandle.
getShortProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the short property with the specified name.
getSQSMessageDeduplicationId() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Get SQS Message Deduplication Id (applicable for FIFO queues, available also as JMS property 'JMS_SQS_DeduplicationId')
getSQSMessageGroupId() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Get SQS Message Group Id (applicable for FIFO queues, available also as JMS property 'JMSXGroupId')
getSQSMessageId() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Get SQS Message Id.
getSQSMessageID() - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
Returns the SQS message id assigned on send.
getSQSMessageSequenceNumber() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Get SQS Message Sequence Number (applicable for FIFO queues, available also as JMS property 'JMS_SQS_SequenceNumber')
getStringMessageAttributeValue() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage.JMSMessagePropertyValue
 
getStringProperty(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Returns the value of the String property with the specified name.
getText() - Method in class com.amazon.sqs.javamessaging.message.SQSTextMessage
Gets the text containing this message's body.
getTimeToLive() - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
getTransacted() - Method in class com.amazon.sqs.javamessaging.SQSSession
SQS does not support transacted.
getType() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage.JMSMessagePropertyValue
 
getUnAckMessages() - Method in interface com.amazon.sqs.javamessaging.acknowledge.Acknowledger
Used in negative acknowledge.
getUnAckMessages() - Method in class com.amazon.sqs.javamessaging.acknowledge.AutoAcknowledger
AutoAcknowledge doesn't need to do anything in this method.
getUnAckMessages() - Method in class com.amazon.sqs.javamessaging.acknowledge.RangedAcknowledger
Returns the list of all consumed but not acknowledged messages.
getUnAckMessages() - Method in class com.amazon.sqs.javamessaging.acknowledge.UnorderedAcknowledger
Returns the list of all consumed but not acknowledged messages.
getValue() - Method in class com.amazon.sqs.javamessaging.message.SQSMessage.JMSMessagePropertyValue
 
getWrappedAmazonSQSClient() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Get a wrapped version of the AmazonSQSClient used by this connection.

H

hashCode() - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
 
hashCode() - Method in record class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch.MessageManager
Returns a hash code value for this object.
hashCode() - Method in class com.amazon.sqs.javamessaging.SQSQueueDestination
 

I

INT - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
INT_FALSE - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
INT_TRUE - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
isBodyAssignableTo(Class) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
isClosed() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
isFifo() - Method in class com.amazon.sqs.javamessaging.SQSQueueDestination
 

J

JMS_SQS_CORRELATION_ID - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 
JMS_SQS_DEDUPLICATION_ID - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
JMS_SQS_MESSAGE_TYPE - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 
JMS_SQS_REPLY_TO_QUEUE_NAME - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 
JMS_SQS_REPLY_TO_QUEUE_URL - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 
JMS_SQS_SEQUENCE_NUMBER - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
JMSMessagePropertyValue(Object) - Constructor for class com.amazon.sqs.javamessaging.message.SQSMessage.JMSMessagePropertyValue
 
JMSMessagePropertyValue(Object, String) - Constructor for class com.amazon.sqs.javamessaging.message.SQSMessage.JMSMessagePropertyValue
 
JMSMessagePropertyValue(String, String) - Constructor for class com.amazon.sqs.javamessaging.message.SQSMessage.JMSMessagePropertyValue
 
JMSX_DELIVERY_COUNT - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
JMSX_GROUP_ID - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
JMSX_GROUP_SEC - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 

L

LONG - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 

M

MAX_BATCH - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
message() - Method in record class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch.MessageManager
Returns the value of the message record component.
MESSAGE_DEDUPLICATION_ID - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
MESSAGE_GROUP_ID - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
MESSAGE_ID_FORMAT - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
messageDispatched() - Method in interface com.amazon.sqs.javamessaging.PrefetchManager
Notify the prefetchThread that the message is dispatched from messageQueue when user calls for receive or message listener onMessage is called.
messageDispatched() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
messageListenerReady() - Method in interface com.amazon.sqs.javamessaging.PrefetchManager
Notify the prefetchThread that the message listener has finished with any previous message and is ready to accept another.
messageListenerReady() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
MessageManager(PrefetchManager, Message) - Constructor for record class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch.MessageManager
Creates an instance of a MessageManager record class.
messageQueue - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Internal buffer of Messages.
messagesPrefetched - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Counter on how many messages are prefetched into internal messageQueue.
messagesRequested - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Counter on how many messages have been explicitly requested.
MIN_BATCH - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
MIN_PREFETCH - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 

N

nackQueueMessages() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
NegativeAcknowledger - Class in com.amazon.sqs.javamessaging.acknowledge
Used to negative acknowledge of group of messages.
NegativeAcknowledger(AmazonSQSMessagingClientWrapper) - Constructor for class com.amazon.sqs.javamessaging.acknowledge.NegativeAcknowledger
 
newThread(Runnable) - Method in class com.amazon.sqs.javamessaging.util.SQSMessagingClientThreadFactory
Constructs a new Thread.
notifyMessageReceived(SQSMessage) - Method in interface com.amazon.sqs.javamessaging.acknowledge.Acknowledger
Used when receiving messages.
notifyMessageReceived(SQSMessage) - Method in class com.amazon.sqs.javamessaging.acknowledge.AutoAcknowledger
When notify message is received, it will acknowledge the message.
notifyMessageReceived(SQSMessage) - Method in class com.amazon.sqs.javamessaging.acknowledge.RangedAcknowledger
Updates the internal queue for the consumed but not acknowledged messages if the message was not already on queue.
notifyMessageReceived(SQSMessage) - Method in class com.amazon.sqs.javamessaging.acknowledge.UnorderedAcknowledger
Updates the internal data structure for the consumed but not acknowledged message.
notifyStateChange() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
NUMBER - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 

O

OBJECT_MESSAGE_TYPE - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 

P

PREFETCH_EXECUTOR_GRACEFUL_SHUTDOWN_TIME - Static variable in class com.amazon.sqs.javamessaging.SQSMessageConsumer
 
prefetchManager() - Method in record class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch.MessageManager
Returns the value of the prefetchManager record component.
PrefetchManager - Interface in com.amazon.sqs.javamessaging
This interface is helper to notify when the prefetchThread should be resuming messages.
processReceivedMessages(List<Message>) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Converts the received message to JMS message, and pushes to messages to either callback scheduler for asynchronous message delivery or to internal buffers for synchronous message delivery.
propertyExists(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Indicates whether a property value exists for the given property name.
ProviderConfiguration - Class in com.amazon.sqs.javamessaging
 
ProviderConfiguration() - Constructor for class com.amazon.sqs.javamessaging.ProviderConfiguration
 

Q

queueExists(String) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Check if the requested queue exists.
queueExists(String, String) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Check if the requested queue exists.

R

RangedAcknowledger - Class in com.amazon.sqs.javamessaging.acknowledge
Used to acknowledge group of messages.
RangedAcknowledger(AmazonSQSMessagingClientWrapper, SQSSession) - Constructor for class com.amazon.sqs.javamessaging.acknowledge.RangedAcknowledger
 
readBoolean() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a boolean from the bytes message stream.
readByte() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a signed 8-bit value from the bytes message stream.
readBytes(byte[]) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a byte array from the bytes message stream.
readBytes(byte[], int) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a portion of the bytes message stream.
readChar() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a Unicode character value from the bytes message stream.
readDouble() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a double from the bytes message stream.
readFloat() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a float from the bytes message stream.
readInt() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a 32-bit integer from the bytes message stream.
readLong() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a 64-bit integer from the bytes message stream.
readShort() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a signed 16-bit number from the bytes message stream.
readUnsignedByte() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads an unsigned 8-bit value from the bytes message stream.
readUnsignedShort() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads an unsigned 16-bit number from the bytes message stream.
readUTF() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Reads a string that has been encoded using a UTF-8 format from the bytes message stream
receive() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
This call blocks indefinitely until a message is produced or until this message consumer is closed.
receive(long) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
This call blocks until a message arrives, the timeout expires, or this message consumer is closed.
receiveMessage(ReceiveMessageRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls receiveMessage and wraps SdkException.
receiveNoWait() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
Receives the next message if one is immediately available.
recover() - Method in class com.amazon.sqs.javamessaging.SQSSession
Negative acknowledges all the messages on the session that is delivered but not acknowledged.
reset() - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Puts the message body in read-only mode and repositions the stream of bytes to the beginning.
retriesAttempted - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Controls the number of retry attempts to the SQS
rollback() - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
run() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Runs until the message consumer is closed and in-progress SQS receiveMessage call returns.
run() - Method in class com.amazon.sqs.javamessaging.SQSSession
 
run() - Method in class com.amazon.sqs.javamessaging.SQSSessionCallbackScheduler
 
running - Variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 

S

send(Destination, Message) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sends a message to a queue destination.
send(Destination, Message, int, int, long) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sends a message to a queue destination.
send(Destination, Message, int, int, long, CompletionListener) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
 
send(Destination, Message, CompletionListener) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
 
send(Message) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sends a message to a destination created during the creation time of this message producer.
send(Message, int, int, long) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sends a message to a destination created during the creation time of this message producer.
send(Message, int, int, long, CompletionListener) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
 
send(Message, CompletionListener) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
 
send(Queue, Message) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sends a message to a queue.
send(Queue, Message, int, int, long) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sends a message to a queue.
sendMessage(SendMessageRequest) - Method in class com.amazon.sqs.javamessaging.AmazonSQSMessagingClientWrapper
Calls sendMessage and wraps AmazonClientException.
SENT_TIMESTAMP - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
SEQUENCE_NUMBER - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
serialize(Serializable) - Static method in class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Serialize the Serializable object to String.
serializePropertyName(String) - Static method in class com.amazon.sqs.javamessaging.util.SQSMessagingClientUtil
Keeping alphabet, numeric characters, hyphens, underscores, or dots.
setBodyWritePermissions(boolean) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setBooleanProperty(String, boolean) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a boolean property value with the specified name into the message.
setByteProperty(String, byte) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a byte property value with the specified name into the message.
setClientID(String) - Method in class com.amazon.sqs.javamessaging.SQSConnection
Sets the client identifier for this connection.
setDeliveryDelay(long) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
Sets the minimum length of time in milliseconds that must elapse after a message is sent before the JMS provider may deliver the message to a consumer.
setDeliveryMode(int) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
setDisableMessageID(boolean) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
setDisableMessageTimestamp(boolean) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
setDoubleProperty(String, double) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a double property value with the specified name into the message.
setExceptionListener(ExceptionListener) - Method in class com.amazon.sqs.javamessaging.SQSConnection
 
setFloatProperty(String, float) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a float property value with the specified name into the message.
setIntProperty(String, int) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a int property value with the specified name into the message.
setJMSCorrelationID(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSCorrelationIDAsBytes(byte[]) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSDeliveryMode(int) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSDeliveryTime(long) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSDestination(Destination) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets the Destination object for this message.
setJMSExpiration(long) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSMessageID(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets the message ID.
setJMSPriority(int) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSRedelivered(boolean) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSReplyTo(Destination) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSTimestamp(long) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setJMSType(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
 
setLongProperty(String, long) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a long property value with the specified name into the message.
setMessageListener(MessageListener) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
Sets the message consumer's MessageListener.
setMessageListener(MessageListener) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Sets the message listener.
setMessageListener(MessageListener) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
setNumberOfMessagesToPrefetch(int) - Method in class com.amazon.sqs.javamessaging.ProviderConfiguration
 
setObject(Serializable) - Method in class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Sets the Serializable containing this message's body
setObjectProperty(String, Object) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a Java object property value with the specified name into the message.
setPriority(int) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
setSequenceNumber(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
This method sets the JMS_SQS_SEQUENCE_NUMBER property on the message.
setShortProperty(String, short) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a short property value with the specified name into the message.
setSQSMessageId(String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Set SQS Message Id, used on send.
setStringProperty(String, String) - Method in class com.amazon.sqs.javamessaging.message.SQSMessage
Sets a String property value with the specified name into the message.
setText(String) - Method in class com.amazon.sqs.javamessaging.message.SQSTextMessage
Sets the text containing this message's body.
setTimeToLive(long) - Method in class com.amazon.sqs.javamessaging.SQSMessageProducer
This method is not supported.
SHORT - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
sleep(long) - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
Sleeps for the configured time.
SQSBytesMessage - Class in com.amazon.sqs.javamessaging.message
This class borrows from ActiveMQStreamMessage, which is also licensed under Apache2.0.
SQSBytesMessage() - Constructor for class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Create new empty BytesMessage to send.
SQSBytesMessage(Acknowledger, String, Message) - Constructor for class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Convert received SQSMessage into BytesMessage.
SQSConnection - Class in com.amazon.sqs.javamessaging
This is a logical connection entity, which encapsulates the logic to create sessions.
SQSConnectionFactory - Class in com.amazon.sqs.javamessaging
A ConnectionFactory object encapsulates a set of connection configuration parameters for SqsClient as well as setting numberOfMessagesToPrefetch.
SQSConnectionFactory(ProviderConfiguration) - Constructor for class com.amazon.sqs.javamessaging.SQSConnectionFactory
Creates a SQSConnectionFactory that uses SqsClientBuilder.standard() for creating SqsClient connections.
SQSConnectionFactory(ProviderConfiguration, SqsClient) - Constructor for class com.amazon.sqs.javamessaging.SQSConnectionFactory
Creates a SQSConnectionFactory that uses the provided SqsClient connection.
SQSConnectionFactory(ProviderConfiguration, SqsClientBuilder) - Constructor for class com.amazon.sqs.javamessaging.SQSConnectionFactory
Creates a SQSConnectionFactory that uses the provided SqsClientBuilder for creating AmazonSQS client connections.
SQSConnectionMetaData - Class in com.amazon.sqs.javamessaging
 
SQSMessage - Class in com.amazon.sqs.javamessaging.message
The SQSMessage is the root class of all SQS JMS messages and implements JMS Message interface.
SQSMessage.JMSMessagePropertyValue - Class in com.amazon.sqs.javamessaging.message
This class is used fulfill object value, corresponding SQS message attribute type and message attribute string value.
SQSMessage.TypeConversionSupport - Class in com.amazon.sqs.javamessaging.message
Copied from org.apache.activemq.util.TypeConversionSupport to provide the same property support provided by activemq without creating a dependency on activemq.
SQSMessageConsumer - Class in com.amazon.sqs.javamessaging
A client uses a MessageConsumer object to receive messages from a destination.
SQSMessageConsumerPrefetch - Class in com.amazon.sqs.javamessaging
Used internally to prefetch messages to internal buffer on a background thread for better receive turn around times.
SQSMessageConsumerPrefetch.MessageManager - Record Class in com.amazon.sqs.javamessaging
 
SQSMessageIdentifier - Class in com.amazon.sqs.javamessaging.acknowledge
Identifies an SQS message, when (negative)acknowledging the message
SQSMessageIdentifier(String, String, String) - Constructor for class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
 
SQSMessageIdentifier(String, String, String, String) - Constructor for class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
 
SQSMessageProducer - Class in com.amazon.sqs.javamessaging
A client uses a MessageProducer object to send messages to a queue destination.
SQSMessagingClientConstants - Class in com.amazon.sqs.javamessaging
 
SQSMessagingClientConstants() - Constructor for class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 
SQSMessagingClientThreadFactory - Class in com.amazon.sqs.javamessaging.util
Simple thread factory that supports ThreadGroups
SQSMessagingClientThreadFactory(String, boolean) - Constructor for class com.amazon.sqs.javamessaging.util.SQSMessagingClientThreadFactory
 
SQSMessagingClientThreadFactory(String, boolean, boolean) - Constructor for class com.amazon.sqs.javamessaging.util.SQSMessagingClientThreadFactory
 
SQSMessagingClientThreadFactory(String, ThreadGroup) - Constructor for class com.amazon.sqs.javamessaging.util.SQSMessagingClientThreadFactory
 
SQSMessagingClientUtil - Class in com.amazon.sqs.javamessaging.util
Includes utility classes to use when serializing property names to SQS message attribute names.
SQSMessagingClientUtil() - Constructor for class com.amazon.sqs.javamessaging.util.SQSMessagingClientUtil
 
SQSObjectMessage - Class in com.amazon.sqs.javamessaging.message
An ObjectMessage object is used to send a message that contains a Java serializable object.
SQSObjectMessage() - Constructor for class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Create new empty ObjectMessage to send.
SQSObjectMessage(Acknowledger, String, Message) - Constructor for class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Convert received SQSMessage into ObjectMessage
SQSObjectMessage(Serializable) - Constructor for class com.amazon.sqs.javamessaging.message.SQSObjectMessage
Create new ObjectMessage with payload to send.
SQSQueueDestination - Class in com.amazon.sqs.javamessaging
A SQSQueueDestination object encapsulates a queue name and SQS specific queue URL.
SQSSession - Class in com.amazon.sqs.javamessaging
A session serves several purposes: It is a factory for its message producers and consumers. It provides a way to create Queue objects for those clients that need to dynamically manipulate provider-specific destination names. It retains messages it consumes until they have been acknowledged. It serializes execution of message listeners registered with its message consumers.
SQSSessionCallbackScheduler - Class in com.amazon.sqs.javamessaging
Used internally to guarantee serial execution of message processing on consumer message listeners.
SQSTextMessage - Class in com.amazon.sqs.javamessaging.message
A TextMessage object is used to send a message body containing a java.lang.String.
SQSTextMessage() - Constructor for class com.amazon.sqs.javamessaging.message.SQSTextMessage
Create new empty TextMessage to send.
SQSTextMessage(Acknowledger, String, Message) - Constructor for class com.amazon.sqs.javamessaging.message.SQSTextMessage
Convert received SQSMessage into TextMessage.
SQSTextMessage(String) - Constructor for class com.amazon.sqs.javamessaging.message.SQSTextMessage
Create new TextMessage with payload to send.
start() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Starts a connection's delivery of incoming messages.
startPrefetch() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
This starts the prefetching
stop() - Method in class com.amazon.sqs.javamessaging.SQSConnection
Stops a connection's delivery of incoming messages.
stopPrefetch() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumer
This stops the prefetching
STRING - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
JMSMessage available user property types, which are mapped to message attribute data types

T

TEXT_MESSAGE_TYPE - Static variable in class com.amazon.sqs.javamessaging.message.SQSMessage
 
toString() - Method in class com.amazon.sqs.javamessaging.acknowledge.SQSMessageIdentifier
 
toString() - Method in record class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch.MessageManager
Returns a string representation of this record class.
toString() - Method in class com.amazon.sqs.javamessaging.SQSQueueDestination
 
TypeConversionSupport() - Constructor for class com.amazon.sqs.javamessaging.message.SQSMessage.TypeConversionSupport
 

U

UNORDERED_ACKNOWLEDGE - Static variable in class com.amazon.sqs.javamessaging.SQSSession
Non standard acknowledge mode.
UnorderedAcknowledger - Class in com.amazon.sqs.javamessaging.acknowledge
Used to acknowledge messages in any order one at a time.
UnorderedAcknowledger(AmazonSQSMessagingClientWrapper, SQSSession) - Constructor for class com.amazon.sqs.javamessaging.acknowledge.UnorderedAcknowledger
 
unsubscribe(String) - Method in class com.amazon.sqs.javamessaging.SQSSession
This method is not supported.
UNSUPPORTED_METHOD - Static variable in class com.amazon.sqs.javamessaging.SQSMessagingClientConstants
 

V

valueOf(String) - Static method in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
Returns the enum constant of this class with the specified name.
values() - Static method in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
Returns an array containing the constants of this enum class, in the order they are declared.

W

WAIT_TIME_SECONDS - Static variable in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
waitForPrefetch() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
waitForStart() - Method in class com.amazon.sqs.javamessaging.SQSMessageConsumerPrefetch
 
wasThreadCreatedWithThisThreadGroup(Thread) - Method in class com.amazon.sqs.javamessaging.util.SQSMessagingClientThreadFactory
Checks if the thread is member of the thread group
withNumberOfMessagesToPrefetch(int) - Method in class com.amazon.sqs.javamessaging.ProviderConfiguration
 
withOriginalAcknowledgeMode(int) - Method in enum class com.amazon.sqs.javamessaging.acknowledge.AcknowledgeMode
Sets the acknowledgment mode.
writeBoolean(boolean) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a boolean to the bytes message stream
writeByte(byte) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a byte to the bytes message stream
writeBytes(byte[]) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a byte array to the bytes message stream
writeBytes(byte[], int, int) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a portion of a byte array to the bytes message stream.
writeChar(char) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a char to the bytes message stream
writeDouble(double) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a double to the bytes message stream
writeFloat(float) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a float to the bytes message stream
writeInt(int) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a int to the bytes message stream
writeLong(long) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a long to the bytes message stream
writeObject(Object) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes an object to the bytes message stream.
writeShort(short) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a short to the bytes message stream
writeUTF(String) - Method in class com.amazon.sqs.javamessaging.message.SQSBytesMessage
Writes a string that has been encoded using a UTF-8 format to the bytes message stream
A B C D E F G H I J L M N O P Q R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values