JMS 1.0.2
A B C D E G I J M N O P Q R S T U W X

A

acknowledge() - Method in interface javax.jms.Message
Acknowledge this and all previous messages received.
AUTO_ACKNOWLEDGE - Static variable in interface javax.jms.Session
With this acknowledgement mode, the session automatically acknowledges a client's receipt of a message when it has either successfully returned from a call to receive or the message listener it has called to process the message successfully returns.

B

BytesMessage - interface javax.jms.BytesMessage.
A BytesMessage is used to send a message containing a stream of uninterpreted bytes.

C

clearBody() - Method in interface javax.jms.Message
Clear out the message body.
clearProperties() - Method in interface javax.jms.Message
Clear a message's properties.
CLIENT_ACKNOWLEDGE - Static variable in interface javax.jms.Session
With this acknowledgement mode, the client acknowledges a message by calling a message's acknowledge method.
close() - Method in interface javax.jms.MessageConsumer
Since a provider may allocate some resources on behalf of a MessageConsumer outside the JVM, clients should close them when they are not needed.
close() - Method in interface javax.jms.QueueBrowser
Since a provider may allocate some resources on behalf of a QueueBrowser outside the JVM, clients should close them when they are not needed.
close() - Method in class javax.jms.QueueRequestor
Since a provider may allocate some resources on behalf of a QueueRequestor outside the JVM, clients should close them when they are not needed.
close() - Method in interface javax.jms.Connection
Since a provider typically allocates significant resources outside the JVM on behalf of a Connection, clients should close them when they are not needed.
close() - Method in interface javax.jms.ConnectionConsumer
Since a provider may allocate some resources on behalf of a ConnectionConsumer outside the JVM, clients should close them when they are not needed.
close() - Method in interface javax.jms.Session
Since a provider may allocate some resources on behalf of a Session outside the JVM, clients should close them when they are not needed.
close() - Method in interface javax.jms.MessageProducer
Since a provider may allocate some resources on behalf of a MessageProducer outside the JVM, clients should close them when they are not needed.
close() - Method in class javax.jms.TopicRequestor
Since a provider may allocate some resources on behalf of a TopicRequestor outside the JVM, clients should close them when they are not needed.
commit() - Method in interface javax.jms.XASession
Throws TransactionInProgressException since it should not be called for an XASession object.
commit() - Method in interface javax.jms.Session
Commit all messages done in this transaction and releases any locks currently held.
Connection - interface javax.jms.Connection.
A JMS Connection is a client's active connection to its JMS provider.
ConnectionConsumer - interface javax.jms.ConnectionConsumer.
For application servers, Connections provide a special facility for creating a ConnectionConsumer (optional).
ConnectionFactory - interface javax.jms.ConnectionFactory.
A ConnectionFactory encapsulates a set of connection configuration parameters that has been defined by an administrator.
ConnectionMetaData - interface javax.jms.ConnectionMetaData.
ConnectionMetaData provides information describing the Connection.
createBrowser(Queue) - Method in interface javax.jms.QueueSession
Create a QueueBrowser to peek at the messages on the specified queue.
createBrowser(Queue, String) - Method in interface javax.jms.QueueSession
Create a QueueBrowser to peek at the messages on the specified queue.
createBytesMessage() - Method in interface javax.jms.Session
Create a BytesMessage.
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in interface javax.jms.QueueConnection
Create a connection consumer for this connection (optional operation).
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in interface javax.jms.TopicConnection
Create a connection consumer for this connection (optional operation).
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in interface javax.jms.TopicConnection
Create a durable connection consumer for this connection (optional operation).
createDurableSubscriber(Topic, String) - Method in interface javax.jms.TopicSession
Create a durable Subscriber to the specified topic.
createDurableSubscriber(Topic, String, String, boolean) - Method in interface javax.jms.TopicSession
Create a durable Subscriber to the specified topic.
createMapMessage() - Method in interface javax.jms.Session
Create a MapMessage.
createMessage() - Method in interface javax.jms.Session
Create a Message.
createObjectMessage() - Method in interface javax.jms.Session
Create an ObjectMessage.
createObjectMessage(Serializable) - Method in interface javax.jms.Session
Create an initialized ObjectMessage.
createPublisher(Topic) - Method in interface javax.jms.TopicSession
Create a Publisher for the specified topic.
createQueue(String) - Method in interface javax.jms.QueueSession
Create a queue identity given a Queue name.
createQueueConnection() - Method in interface javax.jms.QueueConnectionFactory
Create a queue connection with default user identity.
createQueueConnection(String, String) - Method in interface javax.jms.QueueConnectionFactory
Create a queue connection with specified user identity.
createQueueSession(boolean, int) - Method in interface javax.jms.QueueConnection
Create a QueueSession.
createQueueSession(boolean, int) - Method in interface javax.jms.XAQueueConnection
Create an XAQueueSession.
createReceiver(Queue) - Method in interface javax.jms.QueueSession
Create a QueueReceiver to receive messages from the specified queue.
createReceiver(Queue, String) - Method in interface javax.jms.QueueSession
Create a QueueReceiver to receive messages from the specified queue.
createSender(Queue) - Method in interface javax.jms.QueueSession
Create a QueueSender to send messages to the specified queue.
createStreamMessage() - Method in interface javax.jms.Session
Create a StreamMessage.
createSubscriber(Topic) - Method in interface javax.jms.TopicSession
Create a non-durable Subscriber to the specified topic.
createSubscriber(Topic, String, boolean) - Method in interface javax.jms.TopicSession
Create a non-durable Subscriber to the specified topic.
createTemporaryQueue() - Method in interface javax.jms.QueueSession
Create a temporary queue.
createTemporaryTopic() - Method in interface javax.jms.TopicSession
Create a temporary topic.
createTextMessage() - Method in interface javax.jms.Session
Create a TextMessage.
createTextMessage(String) - Method in interface javax.jms.Session
Create an initialized TextMessage.
createTopic(String) - Method in interface javax.jms.TopicSession
Create a topic identity given a Topic name.
createTopicConnection() - Method in interface javax.jms.TopicConnectionFactory
Create a topic connection with default user identity.
createTopicConnection(String, String) - Method in interface javax.jms.TopicConnectionFactory
Create a topic connection with specified user identity.
createTopicSession(boolean, int) - Method in interface javax.jms.TopicConnection
Create a TopicSession
createTopicSession(boolean, int) - Method in interface javax.jms.XATopicConnection
Create an XATopicSession
createXAQueueConnection() - Method in interface javax.jms.XAQueueConnectionFactory
Create an XA queue connection with default user identity.
createXAQueueConnection(String, String) - Method in interface javax.jms.XAQueueConnectionFactory
Create an XA queue connection with specific user identity.
createXAQueueSession() - Method in interface javax.jms.XAQueueConnection
Create an XAQueueSession.
createXATopicConnection() - Method in interface javax.jms.XATopicConnectionFactory
Create an XA topic connection with default user identity.
createXATopicConnection(String, String) - Method in interface javax.jms.XATopicConnectionFactory
Create an XA topic connection with specified user identity.
createXATopicSession() - Method in interface javax.jms.XATopicConnection
Create an XATopicSession.

D

DEFAULT_DELIVERY_MODE - Static variable in interface javax.jms.Message
The message producer's default delivery mode is persistent.
DEFAULT_PRIORITY - Static variable in interface javax.jms.Message
The message producer's default priority is 4.
DEFAULT_TIME_TO_LIVE - Static variable in interface javax.jms.Message
The message producer's default time to live is unlimited, the message never expires.
delete() - Method in interface javax.jms.TemporaryTopic
Delete this temporary topic.
delete() - Method in interface javax.jms.TemporaryQueue
Delete this temporary queue.
DeliveryMode - interface javax.jms.DeliveryMode.
Delivery modes supported by JMS.
Destination - interface javax.jms.Destination.
The Destination object encapsulates provider-specific addresses since JMS does not define a standard address syntax, Although a standard address syntax was considered, it was decided that the differences in address semantics between existing MOM products was too wide to bridge with a single syntax.
DUPS_OK_ACKNOWLEDGE - Static variable in interface javax.jms.Session
This acknowledgement mode instructs the session to lazily acknowledge the delivery of messages.

E

ExceptionListener - interface javax.jms.ExceptionListener.
If a JMS provider detects a serious problem with a Connection it will inform the Connection's ExceptionListener if one has been registered.

G

getBoolean(String) - Method in interface javax.jms.MapMessage
Return the boolean value with the given name.
getBooleanProperty(String) - Method in interface javax.jms.Message
Return the boolean property value with the given name.
getByte(String) - Method in interface javax.jms.MapMessage
Return the byte value with the given name.
getByteProperty(String) - Method in interface javax.jms.Message
Return the byte property value with the given name.
getBytes(String) - Method in interface javax.jms.MapMessage
Return the byte array value with the given name.
getChar(String) - Method in interface javax.jms.MapMessage
Return the Unicode character value with the given name.
getClientID() - Method in interface javax.jms.Connection
Get the client identifier for this connection.
getDeliveryMode() - Method in interface javax.jms.MessageProducer
Get the producer's default delivery mode.
getDisableMessageID() - Method in interface javax.jms.MessageProducer
Get an indication of whether message IDs are disabled.
getDisableMessageTimestamp() - Method in interface javax.jms.MessageProducer
Get an indication of whether message timestamps are disabled.
getDouble(String) - Method in interface javax.jms.MapMessage
Return the double value with the given name.
getDoubleProperty(String) - Method in interface javax.jms.Message
Return the double property value with the given name.
getEnumeration() - Method in interface javax.jms.QueueBrowser
Get an enumeration for browsing the current queue messages in the order they would be received.
getErrorCode() - Method in class javax.jms.JMSException
Get the vendor specific error code
getExceptionListener() - Method in interface javax.jms.Connection
Get the ExceptionListener for this Connection.
getFloat(String) - Method in interface javax.jms.MapMessage
Return the float value with the given name.
getFloatProperty(String) - Method in interface javax.jms.Message
Return the float property value with the given name.
getInt(String) - Method in interface javax.jms.MapMessage
Return the integer value with the given name.
getIntProperty(String) - Method in interface javax.jms.Message
Return the integer property value with the given name.
getJMSCorrelationID() - Method in interface javax.jms.Message
Get the correlation ID for the message.
getJMSCorrelationIDAsBytes() - Method in interface javax.jms.Message
Get the correlation ID as an array of bytes for the message.
getJMSDeliveryMode() - Method in interface javax.jms.Message
Get the delivery mode for this message.
getJMSDestination() - Method in interface javax.jms.Message
Get the destination for this message.
getJMSExpiration() - Method in interface javax.jms.Message
Get the message's expiration value.
getJMSMajorVersion() - Method in interface javax.jms.ConnectionMetaData
Get the JMS major version number.
getJMSMessageID() - Method in interface javax.jms.Message
Get the message ID.
getJMSMinorVersion() - Method in interface javax.jms.ConnectionMetaData
Get the JMS minor version number.
getJMSPriority() - Method in interface javax.jms.Message
Get the message priority.
getJMSProviderName() - Method in interface javax.jms.ConnectionMetaData
Get the JMS provider name.
getJMSRedelivered() - Method in interface javax.jms.Message
Get an indication of whether this message is being redelivered.
getJMSReplyTo() - Method in interface javax.jms.Message
Get where a reply to this message should be sent.
getJMSTimestamp() - Method in interface javax.jms.Message
Get the message timestamp.
getJMSType() - Method in interface javax.jms.Message
Get the message type.
getJMSVersion() - Method in interface javax.jms.ConnectionMetaData
Get the JMS version.
getJMSXPropertyNames() - Method in interface javax.jms.ConnectionMetaData
Get an enumeration of JMSX Property Names.
getLinkedException() - Method in class javax.jms.JMSException
Get the exception linked to this one.
getLong(String) - Method in interface javax.jms.MapMessage
Return the long value with the given name.
getLongProperty(String) - Method in interface javax.jms.Message
Return the long property value with the given name.
getMapNames() - Method in interface javax.jms.MapMessage
Return an Enumeration of all the Map message's names.
getMessageListener() - Method in interface javax.jms.MessageConsumer
Get the message consumer's MessageListener.
getMessageListener() - Method in interface javax.jms.Session
Return the session's distinguished message listener (optional).
getMessageSelector() - Method in interface javax.jms.MessageConsumer
Get this message consumer's message selector expression.
getMessageSelector() - Method in interface javax.jms.QueueBrowser
Get this queue browser's message selector expression.
getMetaData() - Method in interface javax.jms.Connection
Get the meta data for this connection.
getNoLocal() - Method in interface javax.jms.TopicSubscriber
Get the NoLocal attribute for this TopicSubscriber.
getObject() - Method in interface javax.jms.ObjectMessage
Get the serializable object containing this message's data.
getObject(String) - Method in interface javax.jms.MapMessage
Return the Java object value with the given name.
getObjectProperty(String) - Method in interface javax.jms.Message
Return the Java object property value with the given name.
getPriority() - Method in interface javax.jms.MessageProducer
Get the producer's default priority.
getPropertyNames() - Method in interface javax.jms.Message
Return an Enumeration of all the property names.
getProviderMajorVersion() - Method in interface javax.jms.ConnectionMetaData
Get the JMS provider major version number.
getProviderMinorVersion() - Method in interface javax.jms.ConnectionMetaData
Get the JMS provider minor version number.
getProviderVersion() - Method in interface javax.jms.ConnectionMetaData
Get the JMS provider version.
getQueue() - Method in interface javax.jms.QueueBrowser
Get the queue associated with this queue browser.
getQueue() - Method in interface javax.jms.QueueReceiver
Get the queue associated with this queue receiver.
getQueue() - Method in interface javax.jms.QueueSender
Get the queue associated with this queue sender.
getQueueName() - Method in interface javax.jms.Queue
Get the name of this queue.
getQueueSession() - Method in interface javax.jms.XAQueueSession
Get the queue session associated with this XAQueueSession.
getServerSession() - Method in interface javax.jms.ServerSessionPool
Return a server session from the pool.
getServerSessionPool() - Method in interface javax.jms.ConnectionConsumer
Get the server session pool associated with this connection consumer.
getSession() - Method in interface javax.jms.ServerSession
Return the ServerSession's Session.
getShort(String) - Method in interface javax.jms.MapMessage
Return the short value with the given name.
getShortProperty(String) - Method in interface javax.jms.Message
Return the short property value with the given name.
getString(String) - Method in interface javax.jms.MapMessage
Return the String value with the given name.
getStringProperty(String) - Method in interface javax.jms.Message
Return the String property value with the given name.
getText() - Method in interface javax.jms.TextMessage
Get the string containing this message's data.
getTimeToLive() - Method in interface javax.jms.MessageProducer
Get the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system.
getTopic() - Method in interface javax.jms.TopicSubscriber
Get the topic associated with this subscriber.
getTopic() - Method in interface javax.jms.TopicPublisher
Get the topic associated with this publisher.
getTopicName() - Method in interface javax.jms.Topic
Get the name of this topic.
getTopicSession() - Method in interface javax.jms.XATopicSession
Get the topic session associated with this XATopicSession.
getTransacted() - Method in interface javax.jms.XASession
Is the session in transacted mode?
getTransacted() - Method in interface javax.jms.Session
Is the session in transacted mode?
getXAResource() - Method in interface javax.jms.XASession
Return an XA resource to the caller.

I

IllegalStateException - exception javax.jms.IllegalStateException.
This exception is thrown when a method is invoked at an illegal or inappropriate time or if the provider is not in an appropriate state for the requested operation.
IllegalStateException(String) - Constructor for class javax.jms.IllegalStateException
Construct a IllegalStateException with reason.
IllegalStateException(String, String) - Constructor for class javax.jms.IllegalStateException
Construct a IllegalStateException with reason and errorCode for exception
InvalidClientIDException - exception javax.jms.InvalidClientIDException.
This exception must be thrown when a client attempts to set a connection's client id to a value that is rejected by a provider.
InvalidClientIDException(String) - Constructor for class javax.jms.InvalidClientIDException
Construct a InvalidClientIDException with reason.
InvalidClientIDException(String, String) - Constructor for class javax.jms.InvalidClientIDException
Construct a InvalidClientIDException with reason and errorCode for exception
InvalidDestinationException - exception javax.jms.InvalidDestinationException.
This exception must be thrown when a destination is either not understood by a provider or is no longer valid.
InvalidDestinationException(String) - Constructor for class javax.jms.InvalidDestinationException
Construct a InvalidDestinationException with reason.
InvalidDestinationException(String, String) - Constructor for class javax.jms.InvalidDestinationException
Construct a InvalidDestinationException with reason and errorCode for exception
InvalidSelectorException - exception javax.jms.InvalidSelectorException.
This exception must be thrown when a JMS client attempts to give a provider a message selector with invalid syntax.
InvalidSelectorException(String) - Constructor for class javax.jms.InvalidSelectorException
Construct a InvalidSelectorException with reason.
InvalidSelectorException(String, String) - Constructor for class javax.jms.InvalidSelectorException
Construct a InvalidSelectorException with reason and errorCode for exception
itemExists(String) - Method in interface javax.jms.MapMessage
Check if an item exists in this MapMessage.

J

javax.jms - package javax.jms
 
JMSException - exception javax.jms.JMSException.
This is the root class of all JMS exceptions.
JMSException(String) - Constructor for class javax.jms.JMSException
Construct a JMSException with reason and with error code defaulting to null
JMSException(String, String) - Constructor for class javax.jms.JMSException
Construct a JMSException with reason and errorCode for exception
JMSSecurityException - exception javax.jms.JMSSecurityException.
This exception must be thrown when a provider rejects a user name/password submitted by a client.
JMSSecurityException(String) - Constructor for class javax.jms.JMSSecurityException
Construct a JMSSecurityException with reason.
JMSSecurityException(String, String) - Constructor for class javax.jms.JMSSecurityException
Construct a JMSSecurityException with reason and errorCode for exception

M

MapMessage - interface javax.jms.MapMessage.
A MapMessage is used to send a set of name-value pairs where names are Strings and values are Java primitive types.
Message - interface javax.jms.Message.
The Message interface is the root interface of all JMS messages.
MessageConsumer - interface javax.jms.MessageConsumer.
A client uses a message consumer to receive messages from a Destination.
MessageEOFException - exception javax.jms.MessageEOFException.
This exception must be thrown when an unexpected end of stream has been reached when a StreamMessage or BytesMessage is being read.
MessageEOFException(String) - Constructor for class javax.jms.MessageEOFException
Construct a MessageEOFException with reason.
MessageEOFException(String, String) - Constructor for class javax.jms.MessageEOFException
Construct a MessageEOFException with reason and errorCode for exception
MessageFormatException - exception javax.jms.MessageFormatException.
This exception must be thrown when a JMS client attempts to use a data type not supported by a message or attempts to read data in a message as the wrong type.
MessageFormatException(String) - Constructor for class javax.jms.MessageFormatException
Construct a MessageFormatException with reason.
MessageFormatException(String, String) - Constructor for class javax.jms.MessageFormatException
Construct a MessageFormatException with reason and errorCode for exception
MessageListener - interface javax.jms.MessageListener.
A MessageListener is used to receive asynchronously delivered messages.
MessageNotReadableException - exception javax.jms.MessageNotReadableException.
This exception must be thrown when a JMS client attempts to read a write-only message.
MessageNotReadableException(String) - Constructor for class javax.jms.MessageNotReadableException
Construct a MessageNotReadableException with reason.
MessageNotReadableException(String, String) - Constructor for class javax.jms.MessageNotReadableException
Construct a MessageNotReadableException with reason and errorCode for exception
MessageNotWriteableException - exception javax.jms.MessageNotWriteableException.
This exception must be thrown when a JMS client attempts to write to a read-only message.
MessageNotWriteableException(String) - Constructor for class javax.jms.MessageNotWriteableException
Construct a MessageNotWriteableException with reason.
MessageNotWriteableException(String, String) - Constructor for class javax.jms.MessageNotWriteableException
Construct a MessageNotWriteableException with reason and errorCode for exception
MessageProducer - interface javax.jms.MessageProducer.
A client uses a message producer to send messages to a Destination.

N

NON_PERSISTENT - Static variable in interface javax.jms.DeliveryMode
This is the lowest overhead delivery mode because it does not require that the message be logged to stable storage.

O

ObjectMessage - interface javax.jms.ObjectMessage.
An ObjectMessage is used to send a message that contains a serializable Java object.
onException(JMSException) - Method in interface javax.jms.ExceptionListener
Notify user of a JMS exception.
onMessage(Message) - Method in interface javax.jms.MessageListener
Pass a message to the Listener.

P

PERSISTENT - Static variable in interface javax.jms.DeliveryMode
This mode instructs the JMS provider to log the message to stable storage as part of the client's send operation.
propertyExists(String) - Method in interface javax.jms.Message
Check if a property value exists.
publish(Message) - Method in interface javax.jms.TopicPublisher
Publish a Message to the topic Use the topics default delivery mode, timeToLive and priority.
publish(Message, int, int, long) - Method in interface javax.jms.TopicPublisher
Publish a Message to the topic specifying delivery mode, priority and time to live to the topic.
publish(Topic, Message) - Method in interface javax.jms.TopicPublisher
Publish a Message to a topic for an unidentified message producer.
publish(Topic, Message, int, int, long) - Method in interface javax.jms.TopicPublisher
Publish a Message to a topic for an unidentified message producer, specifying delivery mode, priority and time to live.

Q

Queue - interface javax.jms.Queue.
A Queue object encapsulates a provider-specific queue name.
QueueBrowser - interface javax.jms.QueueBrowser.
A client uses a QueueBrowser to look at messages on a queue without removing them.
QueueConnection - interface javax.jms.QueueConnection.
A QueueConnection is an active connection to a JMS PTP provider.
QueueConnectionFactory - interface javax.jms.QueueConnectionFactory.
A client uses a QueueConnectionFactory to create QueueConnections with a JMS PTP provider.
QueueReceiver - interface javax.jms.QueueReceiver.
A client uses a QueueReceiver for receiving messages that have been delivered to a queue.
QueueRequestor - class javax.jms.QueueRequestor.
JMS provides a QueueRequestor helper class to simplify making service requests.
QueueRequestor(QueueSession, Queue) - Constructor for class javax.jms.QueueRequestor
Constructor for the QueueRequestor class.
QueueSender - interface javax.jms.QueueSender.
A client uses a QueueSender to send messages to a queue.
QueueSession - interface javax.jms.QueueSession.
A QueueSession provides methods for creating QueueReceiver's, QueueSender's, QueueBrowser's and TemporaryQueues.

R

readBoolean() - Method in interface javax.jms.StreamMessage
Read a boolean from the stream message.
readBoolean() - Method in interface javax.jms.BytesMessage
Read a boolean from the bytes message stream.
readByte() - Method in interface javax.jms.StreamMessage
Read a byte value from the stream message.
readByte() - Method in interface javax.jms.BytesMessage
Read a signed 8-bit value from the bytes message stream.
readBytes(byte[]) - Method in interface javax.jms.StreamMessage
Read a byte array field from the stream message into the specified byte[] object (the read buffer).
readBytes(byte[]) - Method in interface javax.jms.BytesMessage
Read a byte array from the bytes message stream.
readBytes(byte[], int) - Method in interface javax.jms.BytesMessage
Read a portion of the bytes message stream.
readChar() - Method in interface javax.jms.StreamMessage
Read a Unicode character value from the stream message.
readChar() - Method in interface javax.jms.BytesMessage
Read a Unicode character value from the bytes message stream.
readDouble() - Method in interface javax.jms.StreamMessage
Read a double from the stream message.
readDouble() - Method in interface javax.jms.BytesMessage
Read a double from the bytes message stream.
readFloat() - Method in interface javax.jms.StreamMessage
Read a float from the stream message.
readFloat() - Method in interface javax.jms.BytesMessage
Read a float from the bytes message stream.
readInt() - Method in interface javax.jms.StreamMessage
Read a 32-bit integer from the stream message.
readInt() - Method in interface javax.jms.BytesMessage
Read a signed 32-bit integer from the bytes message stream.
readLong() - Method in interface javax.jms.StreamMessage
Read a 64-bit integer from the stream message.
readLong() - Method in interface javax.jms.BytesMessage
Read a signed 64-bit integer from the bytes message stream.
readObject() - Method in interface javax.jms.StreamMessage
Read a Java object from the stream message.
readShort() - Method in interface javax.jms.StreamMessage
Read a 16-bit number from the stream message.
readShort() - Method in interface javax.jms.BytesMessage
Read a signed 16-bit number from the bytes message stream.
readString() - Method in interface javax.jms.StreamMessage
Read in a string from the stream message.
readUnsignedByte() - Method in interface javax.jms.BytesMessage
Read an unsigned 8-bit number from the bytes message stream.
readUnsignedShort() - Method in interface javax.jms.BytesMessage
Read an unsigned 16-bit number from the bytes message stream.
readUTF() - Method in interface javax.jms.BytesMessage
Read in a string that has been encoded using a modified UTF-8 format from the bytes message stream.
receive() - Method in interface javax.jms.MessageConsumer
Receive the next message produced for this message consumer.
receive(long) - Method in interface javax.jms.MessageConsumer
Receive the next message that arrives within the specified timeout interval.
receiveNoWait() - Method in interface javax.jms.MessageConsumer
Receive the next message if one is immediately available.
recover() - Method in interface javax.jms.Session
Stop message delivery in this session, and restart sending messages with the oldest unacknowledged message.
request(Message) - Method in class javax.jms.QueueRequestor
Send a request and wait for a reply.
request(Message) - Method in class javax.jms.TopicRequestor
Send a request and wait for a reply.
reset() - Method in interface javax.jms.StreamMessage
Put the message body in read-only mode, and reposition the stream to the beginning.
reset() - Method in interface javax.jms.BytesMessage
Put the message body in read-only mode, and reposition the stream of bytes to the beginning.
ResourceAllocationException - exception javax.jms.ResourceAllocationException.
This exception is thrown when a provider is unable to allocate the resources required by a method.
ResourceAllocationException(String) - Constructor for class javax.jms.ResourceAllocationException
Construct a ResourceAllocationException with reason.
ResourceAllocationException(String, String) - Constructor for class javax.jms.ResourceAllocationException
Construct a ResourceAllocationException with reason and errorCode for exception
rollback() - Method in interface javax.jms.XASession
Throws TransactionInProgressException since it should not be called for an XASession object.
rollback() - Method in interface javax.jms.Session
Rollback any messages done in this transaction and releases any locks currently held.
run() - Method in interface javax.jms.Session
Only intended to be used by Application Servers (optional operation).

S

send(Message) - Method in interface javax.jms.QueueSender
Send a message to the queue.
send(Message, int, int, long) - Method in interface javax.jms.QueueSender
Send a message specifying delivery mode, priority and time to live to the queue.
send(Queue, Message) - Method in interface javax.jms.QueueSender
Send a message to a queue for an unidentified message producer.
send(Queue, Message, int, int, long) - Method in interface javax.jms.QueueSender
Send a message to a queue for an unidentified message producer, specifying delivery mode, priority and time to live.
ServerSession - interface javax.jms.ServerSession.
A ServerSession is an application server object that is used by a server to associate a thread with a JMS session (optional).
ServerSessionPool - interface javax.jms.ServerSessionPool.
A ServerSessionPool is an object implemented by an application server to provide a pool of ServerSessions for processing the messages of a ConnectionConsumer (optional).
Session - interface javax.jms.Session.
A JMS Session is a single threaded context for producing and consuming messages.
setBoolean(String, boolean) - Method in interface javax.jms.MapMessage
Set a boolean value with the given name, into the Map.
setBooleanProperty(String, boolean) - Method in interface javax.jms.Message
Set a boolean property value with the given name, into the Message.
setByte(String, byte) - Method in interface javax.jms.MapMessage
Set a byte value with the given name, into the Map.
setByteProperty(String, byte) - Method in interface javax.jms.Message
Set a byte property value with the given name, into the Message.
setBytes(String, byte[]) - Method in interface javax.jms.MapMessage
Set a byte array value with the given name, into the Map.
setBytes(String, byte[], int, int) - Method in interface javax.jms.MapMessage
Set a portion of the byte array value with the given name, into the Map.
setChar(String, char) - Method in interface javax.jms.MapMessage
Set a Unicode character value with the given name, into the Map.
setClientID(String) - Method in interface javax.jms.Connection
Set the client identifier for this connection.
setDeliveryMode(int) - Method in interface javax.jms.MessageProducer
Set the producer's default delivery mode.
setDisableMessageID(boolean) - Method in interface javax.jms.MessageProducer
Set whether message IDs are disabled.
setDisableMessageTimestamp(boolean) - Method in interface javax.jms.MessageProducer
Set whether message timestamps are disabled.
setDouble(String, double) - Method in interface javax.jms.MapMessage
Set a double value with the given name, into the Map.
setDoubleProperty(String, double) - Method in interface javax.jms.Message
Set a double property value with the given name, into the Message.
setExceptionListener(ExceptionListener) - Method in interface javax.jms.Connection
Set an exception listener for this connection.
setFloat(String, float) - Method in interface javax.jms.MapMessage
Set a float value with the given name, into the Map.
setFloatProperty(String, float) - Method in interface javax.jms.Message
Set a float property value with the given name, into the Message.
setInt(String, int) - Method in interface javax.jms.MapMessage
Set an integer value with the given name, into the Map.
setIntProperty(String, int) - Method in interface javax.jms.Message
Set an integer property value with the given name, into the Message.
setJMSCorrelationID(String) - Method in interface javax.jms.Message
Set the correlation ID for the message.
setJMSCorrelationIDAsBytes(byte[]) - Method in interface javax.jms.Message
Set the correlation ID as an array of bytes for the message.
setJMSDeliveryMode(int) - Method in interface javax.jms.Message
Set the delivery mode for this message.
setJMSDestination(Destination) - Method in interface javax.jms.Message
Set the destination for this message.
setJMSExpiration(long) - Method in interface javax.jms.Message
Set the message's expiration value.
setJMSMessageID(String) - Method in interface javax.jms.Message
Set the message ID.
setJMSPriority(int) - Method in interface javax.jms.Message
Set the priority for this message.
setJMSRedelivered(boolean) - Method in interface javax.jms.Message
Set to indicate whether this message is being redelivered.
setJMSReplyTo(Destination) - Method in interface javax.jms.Message
Set where a reply to this message should be sent.
setJMSTimestamp(long) - Method in interface javax.jms.Message
Set the message timestamp.
setJMSType(String) - Method in interface javax.jms.Message
Set the message type.
setLinkedException(Exception) - Method in class javax.jms.JMSException
Add a linked Exception.
setLong(String, long) - Method in interface javax.jms.MapMessage
Set a long value with the given name, into the Map.
setLongProperty(String, long) - Method in interface javax.jms.Message
Set a long property value with the given name, into the Message.
setMessageListener(MessageListener) - Method in interface javax.jms.MessageConsumer
Set the message consumer's MessageListener.
setMessageListener(MessageListener) - Method in interface javax.jms.Session
Set the session's distinguished message listener (optional).
setObject(Serializable) - Method in interface javax.jms.ObjectMessage
Set the serializable object containing this message's data.
setObject(String, Object) - Method in interface javax.jms.MapMessage
Set a Java object value with the given name, into the Map.
setObjectProperty(String, Object) - Method in interface javax.jms.Message
Set a Java object property value with the given name, into the Message.
setPriority(int) - Method in interface javax.jms.MessageProducer
Set the producer's default priority.
setShort(String, short) - Method in interface javax.jms.MapMessage
Set a short value with the given name, into the Map.
setShortProperty(String, short) - Method in interface javax.jms.Message
Set a short property value with the given name, into the Message.
setString(String, String) - Method in interface javax.jms.MapMessage
Set a String value with the given name, into the Map.
setStringProperty(String, String) - Method in interface javax.jms.Message
Set a String property value with the given name, into the Message.
setText(String) - Method in interface javax.jms.TextMessage
Set the string containing this message's data.
setTimeToLive(long) - Method in interface javax.jms.MessageProducer
Set the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system.
start() - Method in interface javax.jms.Connection
Start (or restart) a Connection's delivery of incoming messages.
start() - Method in interface javax.jms.ServerSession
Cause the session's run method to be called to process messages that were just assigned to it.
stop() - Method in interface javax.jms.Connection
Used to temporarily stop a Connection's delivery of incoming messages.
StreamMessage - interface javax.jms.StreamMessage.
A StreamMessage is used to send a stream of Java primitives.

T

TemporaryQueue - interface javax.jms.TemporaryQueue.
A TemporaryQueue is a unique Queue object created for the duration of a QueueConnection.
TemporaryTopic - interface javax.jms.TemporaryTopic.
A TemporaryTopic is a unique Topic object created for the duration of a TopicConnection.
TextMessage - interface javax.jms.TextMessage.
A TextMessage is used to send a message containing a java.lang.String.
Topic - interface javax.jms.Topic.
A Topic object encapsulates a provider-specific topic name.
TopicConnection - interface javax.jms.TopicConnection.
A TopicConnection is an active connection to a JMS Pub/Sub provider.
TopicConnectionFactory - interface javax.jms.TopicConnectionFactory.
A client uses a TopicConnectionFactory to create TopicConnections with a JMS Pub/Sub provider.
TopicPublisher - interface javax.jms.TopicPublisher.
A client uses a TopicPublisher for publishing messages on a topic.
TopicRequestor - class javax.jms.TopicRequestor.
JMS provides a TopicRequestor helper class to simplify making service requests.
TopicRequestor(TopicSession, Topic) - Constructor for class javax.jms.TopicRequestor
Constructor for the TopicRequestor class.
TopicSession - interface javax.jms.TopicSession.
A TopicSession provides methods for creating TopicPublisher's, TopicSubscriber's and TemporaryTopics.
TopicSubscriber - interface javax.jms.TopicSubscriber.
A client uses a TopicSubscriber for receiving messages that have been published to a topic.
toString() - Method in interface javax.jms.Queue
Return a pretty printed version of the queue name
toString() - Method in interface javax.jms.Topic
Return a pretty printed version of the topic name.
TransactionInProgressException - exception javax.jms.TransactionInProgressException.
This exception is thrown when an operation is invalid because a transaction is in progress.
TransactionInProgressException(String) - Constructor for class javax.jms.TransactionInProgressException
Construct a TransactionInProgressException with reason.
TransactionInProgressException(String, String) - Constructor for class javax.jms.TransactionInProgressException
Construct a TransactionInProgressException with reason and errorCode for exception
TransactionRolledBackException - exception javax.jms.TransactionRolledBackException.
This exception must be thrown when a call to Session.commit results in a rollback of the current transaction.
TransactionRolledBackException(String) - Constructor for class javax.jms.TransactionRolledBackException
Construct a TransactionRolledBackException with reason.
TransactionRolledBackException(String, String) - Constructor for class javax.jms.TransactionRolledBackException
Construct a TransactionRolledBackException with reason and errorCode for exception

U

unsubscribe(String) - Method in interface javax.jms.TopicSession
Unsubscribe a durable subscription that has been created by a client.

W

writeBoolean(boolean) - Method in interface javax.jms.StreamMessage
Write a boolean to the stream message.
writeBoolean(boolean) - Method in interface javax.jms.BytesMessage
Write a boolean to the bytes message stream as a 1-byte value.
writeByte(byte) - Method in interface javax.jms.StreamMessage
Write out a byte to the stream message.
writeByte(byte) - Method in interface javax.jms.BytesMessage
Write out a byte to the bytes message stream as a 1-byte value.
writeBytes(byte[]) - Method in interface javax.jms.StreamMessage
Write a byte array field to the stream message.
writeBytes(byte[]) - Method in interface javax.jms.BytesMessage
Write a byte array to the bytes message stream.
writeBytes(byte[], int, int) - Method in interface javax.jms.StreamMessage
Write a portion of a byte array as a byte array field to the stream message.
writeBytes(byte[], int, int) - Method in interface javax.jms.BytesMessage
Write a portion of a byte array to the bytes message stream.
writeChar(char) - Method in interface javax.jms.StreamMessage
Write a char to the stream message.
writeChar(char) - Method in interface javax.jms.BytesMessage
Write a char to the bytes message stream as a 2-byte value, high byte first.
writeDouble(double) - Method in interface javax.jms.StreamMessage
Write a double to the stream message.
writeDouble(double) - Method in interface javax.jms.BytesMessage
Convert the double argument to a long using the doubleToLongBits method in class Double, and then writes that long value to the bytes message stream as an 8-byte quantity, high byte first.
writeFloat(float) - Method in interface javax.jms.StreamMessage
Write a float to the stream message.
writeFloat(float) - Method in interface javax.jms.BytesMessage
Convert the float argument to an int using the floatToIntBits method in class Float, and then writes that int value to the bytes message stream as a 4-byte quantity, high byte first.
writeInt(int) - Method in interface javax.jms.StreamMessage
Write an int to the stream message.
writeInt(int) - Method in interface javax.jms.BytesMessage
Write an int to the bytes message stream as four bytes, high byte first.
writeLong(long) - Method in interface javax.jms.StreamMessage
Write a long to the stream message.
writeLong(long) - Method in interface javax.jms.BytesMessage
Write a long to the bytes message stream as eight bytes, high byte first.
writeObject(Object) - Method in interface javax.jms.StreamMessage
Write a Java object to the stream message.
writeObject(Object) - Method in interface javax.jms.BytesMessage
Write a Java object to the bytes message stream.
writeShort(short) - Method in interface javax.jms.StreamMessage
Write a short to the stream message.
writeShort(short) - Method in interface javax.jms.BytesMessage
Write a short to the bytes message stream as two bytes, high byte first.
writeString(String) - Method in interface javax.jms.StreamMessage
Write a string to the stream message.
writeUTF(String) - Method in interface javax.jms.BytesMessage
Write a string to the bytes message stream using UTF-8 encoding in a machine-independent manner.

X

XAConnection - interface javax.jms.XAConnection.
XAConnection extends the capability of Connection by providing an XASession (optional).
XAConnectionFactory - interface javax.jms.XAConnectionFactory.
Some application servers provide support for grouping JTS capable resource use into a distributed transaction (optional).
XAQueueConnection - interface javax.jms.XAQueueConnection.
XAQueueConnection provides the same create options as QueueConnection (optional).
XAQueueConnectionFactory - interface javax.jms.XAQueueConnectionFactory.
An XAQueueConnectionFactory provides the same create options as a QueueConnectionFactory (optional).
XAQueueSession - interface javax.jms.XAQueueSession.
An XAQueueSession provides a regular QueueSession which can be used to create QueueReceivers, QueueSenders and QueueBrowsers (optional).
XASession - interface javax.jms.XASession.
XASession extends the capability of Session by adding access to a JMS provider's support for JTA (optional).
XATopicConnection - interface javax.jms.XATopicConnection.
An XATopicConnection provides the same create options as TopicConnection (optional).
XATopicConnectionFactory - interface javax.jms.XATopicConnectionFactory.
An XATopicConnectionFactory provides the same create options as TopicConnectionFactory (optional).
XATopicSession - interface javax.jms.XATopicSession.
An XATopicSession provides a regular TopicSession which can be used to create TopicSubscribers and TopicPublishers (optional).

A B C D E G I J M N O P Q R S T U W X
JMS 1.0.2

JMS 1.0.2