| Modifier and Type | Class and Description | 
|---|---|
| class  | 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. | 
| class  | 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. | 
| class  | InvalidDestinationException
 This exception must be thrown when a destination either is not understood by a provider or is no longer valid. | 
| class  | InvalidSelectorException
 This exception must be thrown when a Jakarta Messaging client attempts to give a provider a message selector with invalid syntax. | 
| class  | JMSSecurityExceptionThis exception must be thrown when a provider rejects a user name/password submitted by a client. | 
| class  | MessageEOFExceptionThis exception must be thrown when an unexpected end of stream has been reached when a  StreamMessageorBytesMessageis being read. | 
| class  | MessageFormatExceptionThis exception must be thrown when a Jakarta Messaging client attempts to use a data type not supported by a message or attempts to
 read data in a message as the wrong type. | 
| class  | MessageNotReadableExceptionThis exception must be thrown when a Jakarta Messaging client attempts to read a write-only message. | 
| class  | MessageNotWriteableExceptionThis exception must be thrown when a Jakarta Messaging client attempts to write to a read-only message. | 
| class  | ResourceAllocationExceptionThis exception is thrown when a provider is unable to allocate the resources required by a method. | 
| class  | TransactionInProgressExceptionThis exception is thrown when an operation is invalid because a transaction is in progress. | 
| class  | TransactionRolledBackExceptionThis exception must be thrown when a call to  Session.commitresults in a rollback of the current transaction. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ExceptionListener. onException(JMSException exception)Notifies user of a Jakarta Messaging exception. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Message. acknowledge()Acknowledges all consumed messages of the session of this consumed message. | 
| void | Message. clearBody()Clears out the message body. | 
| void | Message. clearProperties()Clears a message's properties. | 
| void | Session. close()Closes the session. | 
| void | ConnectionConsumer. close()Closes the connection consumer. | 
| void | Connection. close()Closes the connection. | 
| void | QueueBrowser. close()Closes the  QueueBrowser. | 
| void | QueueRequestor. close()Closes the  QueueRequestorand its session. | 
| void | MessageProducer. close()Closes the message producer. | 
| void | TopicRequestor. close()Closes the  TopicRequestorand its session. | 
| void | MessageConsumer. close()Closes the message consumer. | 
| void | Session. commit()Commits all messages done in this transaction and releases any locks currently held. | 
| void | XASession. commit()Throws a  TransactionInProgressException, since it should not be called for anXASessionobject. | 
| QueueBrowser | Session. createBrowser(Queue queue)Creates a  QueueBrowserobject to peek at the messages on the specified queue. | 
| QueueBrowser | QueueSession. createBrowser(Queue queue)Creates a  QueueBrowserobject to peek at the messages on the specified queue. | 
| QueueBrowser | Session. createBrowser(Queue queue,
             String messageSelector)Creates a  QueueBrowserobject to peek at the messages on the specified queue using a message selector. | 
| QueueBrowser | QueueSession. createBrowser(Queue queue,
             String messageSelector)Creates a  QueueBrowserobject to peek at the messages on the specified queue using a message selector. | 
| BytesMessage | Session. createBytesMessage()Creates a  BytesMessageobject. | 
| Connection | ConnectionFactory. createConnection()Creates a connection with the default user identity. | 
| Connection | ConnectionFactory. createConnection(String userName,
                String password)Creates a connection with the specified user identity. | 
| ConnectionConsumer | Connection. createConnectionConsumer(Destination destination,
                        String messageSelector,
                        ServerSessionPool sessionPool,
                        int maxMessages)Creates a connection consumer for this connection (optional operation) on the specific destination. | 
| ConnectionConsumer | QueueConnection. createConnectionConsumer(Queue queue,
                        String messageSelector,
                        ServerSessionPool sessionPool,
                        int maxMessages)Creates a connection consumer for this connection (optional operation). | 
| ConnectionConsumer | TopicConnection. createConnectionConsumer(Topic topic,
                        String messageSelector,
                        ServerSessionPool sessionPool,
                        int maxMessages)Creates a connection consumer for this connection (optional operation). | 
| MessageConsumer | Session. createConsumer(Destination destination)Creates a  MessageConsumerfor the specified destination. | 
| MessageConsumer | Session. createConsumer(Destination destination,
              String messageSelector)Creates a  MessageConsumerfor the specified destination, using a message selector. | 
| MessageConsumer | Session. createConsumer(Destination destination,
              String messageSelector,
              boolean noLocal)Creates a  MessageConsumerfor the specified destination, specifying a message selector and thenoLocalparameter. | 
| ConnectionConsumer | Connection. createDurableConnectionConsumer(Topic topic,
                               String subscriptionName,
                               String messageSelector,
                               ServerSessionPool sessionPool,
                               int maxMessages)Creates a connection consumer for this connection (optional operation) on the specific topic using an unshared
 durable subscription with the specified name. | 
| ConnectionConsumer | TopicConnection. createDurableConnectionConsumer(Topic topic,
                               String subscriptionName,
                               String messageSelector,
                               ServerSessionPool sessionPool,
                               int maxMessages)Create a durable connection consumer for this connection (optional operation). | 
| MessageConsumer | Session. createDurableConsumer(Topic topic,
                     String name)Creates an unshared durable subscription on the specified topic (if one does not already exist) and creates a
 consumer on that durable subscription. | 
| MessageConsumer | Session. createDurableConsumer(Topic topic,
                     String name,
                     String messageSelector,
                     boolean noLocal)Creates an unshared durable subscription on the specified topic (if one does not already exist), specifying a message
 selector and the  noLocalparameter, and creates a consumer on that durable subscription. | 
| TopicSubscriber | Session. createDurableSubscriber(Topic topic,
                       String name)Creates an unshared durable subscription on the specified topic (if one does not already exist) and creates a
 consumer on that durable subscription. | 
| TopicSubscriber | TopicSession. createDurableSubscriber(Topic topic,
                       String name)Creates an unshared durable subscription on the specified topic (if one does not already exist) and creates a
 consumer on that durable subscription. | 
| TopicSubscriber | Session. createDurableSubscriber(Topic topic,
                       String name,
                       String messageSelector,
                       boolean noLocal)Creates an unshared durable subscription on the specified topic (if one does not already exist), specifying a message
 selector and the  noLocalparameter, and creates a consumer on that durable subscription. | 
| TopicSubscriber | TopicSession. createDurableSubscriber(Topic topic,
                       String name,
                       String messageSelector,
                       boolean noLocal)Creates an unshared durable subscription on the specified topic (if one does not already exist), specifying a message
 selector and the  noLocalparameter, and creates a consumer on that durable subscription. | 
| MapMessage | Session. createMapMessage()Creates a  MapMessageobject. | 
| Message | Session. createMessage()Creates a  Messageobject. | 
| ObjectMessage | Session. createObjectMessage()Creates an  ObjectMessageobject. | 
| ObjectMessage | Session. createObjectMessage(Serializable object)Creates an initialized  ObjectMessageobject. | 
| MessageProducer | Session. createProducer(Destination destination)Creates a  MessageProducerto send messages to the specified destination. | 
| TopicPublisher | TopicSession. createPublisher(Topic topic)Creates a publisher for the specified topic. | 
| Queue | Session. createQueue(String queueName)Creates a  Queueobject which encapsulates a specified provider-specific queue name. | 
| Queue | QueueSession. createQueue(String queueName)Creates a queue identity given a  Queuename. | 
| QueueConnection | QueueConnectionFactory. createQueueConnection()Creates a queue connection with the default user identity. | 
| QueueConnection | QueueConnectionFactory. createQueueConnection(String userName,
                     String password)Creates a queue connection with the specified user identity. | 
| QueueSession | QueueConnection. createQueueSession(boolean transacted,
                  int acknowledgeMode)Creates a  QueueSessionobject, specifyingtransactedandacknowledgeMode. | 
| QueueSession | XAQueueConnection. createQueueSession(boolean transacted,
                  int acknowledgeMode)Creates a  QueueSessionobject. | 
| QueueReceiver | QueueSession. createReceiver(Queue queue)Creates a  QueueReceiverobject to receive messages from the specified queue. | 
| QueueReceiver | QueueSession. createReceiver(Queue queue,
              String messageSelector)Creates a  QueueReceiverobject to receive messages from the specified queue using a message selector. | 
| QueueSender | QueueSession. createSender(Queue queue)Creates a  QueueSenderobject to send messages to the specified queue. | 
| Session | Connection. createSession()Creates a  Sessionobject, specifying no arguments. | 
| Session | Connection. createSession(boolean transacted,
             int acknowledgeMode)Creates a  Sessionobject, specifyingtransactedandacknowledgeMode. | 
| Session | XAConnection. createSession(boolean transacted,
             int acknowledgeMode)Creates an  Sessionobject. | 
| Session | Connection. createSession(int sessionMode)Creates a  Sessionobject, specifyingsessionMode. | 
| ConnectionConsumer | Connection. createSharedConnectionConsumer(Topic topic,
                              String subscriptionName,
                              String messageSelector,
                              ServerSessionPool sessionPool,
                              int maxMessages)Creates a connection consumer for this connection (optional operation) on the specific topic using a shared
 non-durable subscription with the specified name. | 
| MessageConsumer | Session. createSharedConsumer(Topic topic,
                    String sharedSubscriptionName)Creates a shared non-durable subscription with the specified name on the specified topic (if one does not already
 exist) and creates a consumer on that subscription. | 
| MessageConsumer | Session. createSharedConsumer(Topic topic,
                    String sharedSubscriptionName,
                    String messageSelector)Creates a shared non-durable subscription with the specified name on the specified topic (if one does not already
 exist) specifying a message selector, and creates a consumer on that subscription. | 
| ConnectionConsumer | Connection. createSharedDurableConnectionConsumer(Topic topic,
                                     String subscriptionName,
                                     String messageSelector,
                                     ServerSessionPool sessionPool,
                                     int maxMessages)Creates a connection consumer for this connection (optional operation) on the specific topic using a shared durable
 subscription with the specified name. | 
| MessageConsumer | Session. createSharedDurableConsumer(Topic topic,
                           String name)Creates a shared durable subscription on the specified topic (if one does not already exist), specifying a message
 selector and the  noLocalparameter, and creates a consumer on that durable subscription. | 
| MessageConsumer | Session. createSharedDurableConsumer(Topic topic,
                           String name,
                           String messageSelector)Creates a shared durable subscription on the specified topic (if one does not already exist), specifying a message
 selector, and creates a consumer on that durable subscription. | 
| StreamMessage | Session. createStreamMessage()Creates a  StreamMessageobject. | 
| TopicSubscriber | TopicSession. createSubscriber(Topic topic)Creates a nondurable subscriber to the specified topic. | 
| TopicSubscriber | TopicSession. createSubscriber(Topic topic,
                String messageSelector,
                boolean noLocal)Creates a nondurable subscriber to the specified topic, using a message selector or specifying whether messages
 published by its own connection should be delivered to it. | 
| TemporaryQueue | Session. createTemporaryQueue()Creates a  TemporaryQueueobject. | 
| TemporaryQueue | QueueSession. createTemporaryQueue()Creates a  TemporaryQueueobject. | 
| TemporaryTopic | Session. createTemporaryTopic()Creates a  TemporaryTopicobject. | 
| TemporaryTopic | TopicSession. createTemporaryTopic()Creates a  TemporaryTopicobject. | 
| TextMessage | Session. createTextMessage()Creates a  TextMessageobject. | 
| TextMessage | Session. createTextMessage(String text)Creates an initialized  TextMessageobject. | 
| Topic | Session. createTopic(String topicName)Creates a  Topicobject which encapsulates a specified provider-specific topic name. | 
| Topic | TopicSession. createTopic(String topicName)Creates a topic identity given a  Topicname. | 
| TopicConnection | TopicConnectionFactory. createTopicConnection()Creates a topic connection with the default user identity. | 
| TopicConnection | TopicConnectionFactory. createTopicConnection(String userName,
                     String password)Creates a topic connection with the specified user identity. | 
| TopicSession | XATopicConnection. createTopicSession(boolean transacted,
                  int acknowledgeMode)Creates a  TopicSessionobject. | 
| TopicSession | TopicConnection. createTopicSession(boolean transacted,
                  int acknowledgeMode)Creates a  TopicSessionobject, specifyingtransactedandacknowledgeMode. | 
| XAConnection | XAConnectionFactory. createXAConnection()Creates an  XAConnectionwith the default user identity. | 
| XAConnection | XAConnectionFactory. createXAConnection(String userName,
                  String password)Creates an  XAConnectionwith the specified user identity. | 
| XAQueueConnection | XAQueueConnectionFactory. createXAQueueConnection()Creates an XA queue connection with the default user identity. | 
| XAQueueConnection | XAQueueConnectionFactory. createXAQueueConnection(String userName,
                       String password)Creates an XA queue connection with the specified user identity. | 
| XAQueueSession | XAQueueConnection. createXAQueueSession()Creates an  XAQueueSessionobject. | 
| XASession | XAConnection. createXASession()Creates an  XASessionobject. | 
| XATopicConnection | XATopicConnectionFactory. createXATopicConnection()Creates an XA topic connection with the default user identity. | 
| XATopicConnection | XATopicConnectionFactory. createXATopicConnection(String userName,
                       String password)Creates an XA topic connection with the specified user identity. | 
| XATopicSession | XATopicConnection. createXATopicSession()Creates an  XATopicSessionobject. | 
| void | TemporaryQueue. delete()Deletes this temporary queue. | 
| void | TemporaryTopic. delete()Deletes this temporary topic. | 
| int | Session. getAcknowledgeMode()Returns the acknowledgement mode of the session. | 
| <T> T | Message. getBody(Class<T> c)Returns the message body as an object of the specified type. | 
| long | BytesMessage. getBodyLength()Gets the number of bytes of the message body when the message is in read-only mode. | 
| boolean | MapMessage. getBoolean(String name)Returns the  booleanvalue with the specified name. | 
| boolean | Message. getBooleanProperty(String name)Returns the value of the  booleanproperty with the specified name. | 
| byte | MapMessage. getByte(String name)Returns the  bytevalue with the specified name. | 
| byte | Message. getByteProperty(String name)Returns the value of the  byteproperty with the specified name. | 
| byte[] | MapMessage. getBytes(String name)Returns the byte array value with the specified name. | 
| char | MapMessage. getChar(String name)Returns the Unicode character value with the specified name. | 
| String | Connection. getClientID()Gets the client identifier for this connection. | 
| long | MessageProducer. getDeliveryDelay()Gets the minimum length of time in milliseconds that must elapse after a message is sent before the Jakarta Messaging provider may
 deliver the message to a consumer. | 
| int | MessageProducer. getDeliveryMode()Gets the producer's default delivery mode. | 
| Destination | MessageProducer. getDestination()Gets the destination associated with this  MessageProducer. | 
| boolean | MessageProducer. getDisableMessageID()Gets an indication of whether message IDs are disabled. | 
| boolean | MessageProducer. getDisableMessageTimestamp()Gets an indication of whether message timestamps are disabled. | 
| double | MapMessage. getDouble(String name)Returns the  doublevalue with the specified name. | 
| double | Message. getDoubleProperty(String name)Returns the value of the  doubleproperty with the specified name. | 
| Enumeration | QueueBrowser. getEnumeration()Gets an enumeration for browsing the current queue messages in the order they would be received. | 
| ExceptionListener | Connection. getExceptionListener()Gets the  ExceptionListenerobject for this connection. | 
| float | MapMessage. getFloat(String name)Returns the  floatvalue with the specified name. | 
| float | Message. getFloatProperty(String name)Returns the value of the  floatproperty with the specified name. | 
| int | MapMessage. getInt(String name)Returns the  intvalue with the specified name. | 
| int | Message. getIntProperty(String name)Returns the value of the  intproperty with the specified name. | 
| String | Message. getJMSCorrelationID()Gets the correlation ID for the message. | 
| byte[] | Message. getJMSCorrelationIDAsBytes()Gets the correlation ID as an array of bytes for the message. | 
| int | Message. getJMSDeliveryMode()Gets the  DeliveryModevalue specified for this message. | 
| long | Message. getJMSDeliveryTime()Gets the message's delivery time value. | 
| Destination | Message. getJMSDestination()Gets the  Destinationobject for this message. | 
| long | Message. getJMSExpiration()Gets the message's expiration time. | 
| int | ConnectionMetaData. getJMSMajorVersion()Gets the Jakarta Messaging major version number. | 
| String | Message. getJMSMessageID()Gets the message ID. | 
| int | ConnectionMetaData. getJMSMinorVersion()Gets the Jakarta Messaging minor version number. | 
| int | Message. getJMSPriority()Gets the message priority level. | 
| String | ConnectionMetaData. getJMSProviderName()Gets the Jakarta Messaging provider name. | 
| boolean | Message. getJMSRedelivered()Gets an indication of whether this message is being redelivered. | 
| Destination | Message. getJMSReplyTo()Gets the  Destinationobject to which a reply to this message should be sent. | 
| long | Message. getJMSTimestamp()Gets the message timestamp. | 
| String | Message. getJMSType()Gets the message type identifier supplied by the client when the message was sent. | 
| String | ConnectionMetaData. getJMSVersion()Gets the Jakarta Messaging API version. | 
| Enumeration | ConnectionMetaData. getJMSXPropertyNames()Gets an enumeration of the JMSX property names. | 
| long | MapMessage. getLong(String name)Returns the  longvalue with the specified name. | 
| long | Message. getLongProperty(String name)Returns the value of the  longproperty with the specified name. | 
| Enumeration | MapMessage. getMapNames()Returns an  Enumerationof all the names in theMapMessageobject. | 
| MessageListener | Session. getMessageListener()Returns the session's distinguished message listener (optional). | 
| MessageListener | MessageConsumer. getMessageListener()Gets the  MessageConsumer'sMessageListener. | 
| String | QueueBrowser. getMessageSelector()Gets this queue browser's message selector expression. | 
| String | MessageConsumer. getMessageSelector()Gets this message consumer's message selector expression. | 
| ConnectionMetaData | Connection. getMetaData()Gets the metadata for this connection. | 
| boolean | TopicSubscriber. getNoLocal()Gets the  NoLocalattribute for this subscriber. | 
| Serializable | ObjectMessage. getObject()Gets the serializable object containing this message's data. | 
| Object | MapMessage. getObject(String name)Returns the value of the object with the specified name. | 
| Object | Message. getObjectProperty(String name)Returns the value of the Java object property with the specified name. | 
| int | MessageProducer. getPriority()Gets the producer's default priority. | 
| Enumeration | Message. getPropertyNames()Returns an  Enumerationof all the property names. | 
| int | ConnectionMetaData. getProviderMajorVersion()Gets the Jakarta Messaging provider major version number. | 
| int | ConnectionMetaData. getProviderMinorVersion()Gets the Jakarta Messaging provider minor version number. | 
| String | ConnectionMetaData. getProviderVersion()Gets the Jakarta Messaging provider version. | 
| Queue | QueueSender. getQueue()Gets the queue associated with this  QueueSender. | 
| Queue | QueueBrowser. getQueue()Gets the queue associated with this queue browser. | 
| Queue | QueueReceiver. getQueue()Gets the  Queueassociated with this queue receiver. | 
| String | Queue. getQueueName()Gets the name of this queue. | 
| QueueSession | XAQueueSession. getQueueSession()Gets the queue session associated with this  XAQueueSession. | 
| ServerSession | ServerSessionPool. getServerSession()Return a server session from the pool. | 
| ServerSessionPool | ConnectionConsumer. getServerSessionPool()Gets the server session pool associated with this connection consumer. | 
| Session | XASession. getSession()Gets the session associated with this  XASession. | 
| Session | ServerSession. getSession()Return the  ServerSession'sSession. | 
| short | MapMessage. getShort(String name)Returns the  shortvalue with the specified name. | 
| short | Message. getShortProperty(String name)Returns the value of the  shortproperty with the specified name. | 
| String | MapMessage. getString(String name)Returns the  Stringvalue with the specified name. | 
| String | Message. getStringProperty(String name)Returns the value of the  Stringproperty with the specified name. | 
| String | TextMessage. getText()Gets the string containing this message's data. | 
| long | MessageProducer. getTimeToLive()Gets the default length of time in milliseconds from its dispatch time that a produced message should be retained by
 the message system. | 
| Topic | TopicSubscriber. getTopic()Gets the  Topicassociated with this subscriber. | 
| Topic | TopicPublisher. getTopic()Gets the topic associated with this  TopicPublisher. | 
| String | Topic. getTopicName()Gets the name of this topic. | 
| TopicSession | XATopicSession. getTopicSession()Gets the topic session associated with this  XATopicSession. | 
| boolean | Session. getTransacted()Indicates whether the session is in transacted mode. | 
| boolean | XASession. getTransacted()Indicates whether the session is in transacted mode. | 
| boolean | Message. isBodyAssignableTo(Class c)Returns whether the message body is capable of being assigned to the specified type. | 
| boolean | MapMessage. itemExists(String name)Indicates whether an item exists in this  MapMessageobject. | 
| boolean | Message. propertyExists(String name)Indicates whether a property value exists. | 
| void | TopicPublisher. publish(Message message)Publishes a message to the topic. | 
| void | TopicPublisher. publish(Message message,
       int deliveryMode,
       int priority,
       long timeToLive)Publishes a message to the topic, specifying delivery mode, priority, and time to live. | 
| void | TopicPublisher. publish(Topic topic,
       Message message)Publishes a message to a topic for an unidentified message producer. | 
| void | TopicPublisher. publish(Topic topic,
       Message message,
       int deliveryMode,
       int priority,
       long timeToLive)Publishes a message to a topic for an unidentified message producer, specifying delivery mode, priority and time to
 live. | 
| boolean | BytesMessage. readBoolean()Reads a  booleanfrom the bytes message stream. | 
| boolean | StreamMessage. readBoolean()Reads a  booleanfrom the stream message. | 
| byte | BytesMessage. readByte()Reads a signed 8-bit value from the bytes message stream. | 
| byte | StreamMessage. readByte()Reads a  bytevalue from the stream message. | 
| int | BytesMessage. readBytes(byte[] value)Reads a byte array from the bytes message stream. | 
| int | StreamMessage. readBytes(byte[] value)Reads a byte array field from the stream message into the specified  byte[]object (the read buffer). | 
| int | BytesMessage. readBytes(byte[] value,
         int length)Reads a portion of the bytes message stream. | 
| char | BytesMessage. readChar()Reads a Unicode character value from the bytes message stream. | 
| char | StreamMessage. readChar()Reads a Unicode character value from the stream message. | 
| double | BytesMessage. readDouble()Reads a  doublefrom the bytes message stream. | 
| double | StreamMessage. readDouble()Reads a  doublefrom the stream message. | 
| float | BytesMessage. readFloat()Reads a  floatfrom the bytes message stream. | 
| float | StreamMessage. readFloat()Reads a  floatfrom the stream message. | 
| int | BytesMessage. readInt()Reads a signed 32-bit integer from the bytes message stream. | 
| int | StreamMessage. readInt()Reads a 32-bit integer from the stream message. | 
| long | BytesMessage. readLong()Reads a signed 64-bit integer from the bytes message stream. | 
| long | StreamMessage. readLong()Reads a 64-bit integer from the stream message. | 
| Object | StreamMessage. readObject()Reads an object from the stream message. | 
| short | BytesMessage. readShort()Reads a signed 16-bit number from the bytes message stream. | 
| short | StreamMessage. readShort()Reads a 16-bit integer from the stream message. | 
| String | StreamMessage. readString()Reads a  Stringfrom the stream message. | 
| int | BytesMessage. readUnsignedByte()Reads an unsigned 8-bit number from the bytes message stream. | 
| int | BytesMessage. readUnsignedShort()Reads an unsigned 16-bit number from the bytes message stream. | 
| String | BytesMessage. readUTF()Reads a string that has been encoded using a modified UTF-8 format from the bytes message stream. | 
| Message | MessageConsumer. receive()Receives the next message produced for this message consumer. | 
| Message | MessageConsumer. receive(long timeout)Receives the next message that arrives within the specified timeout interval. | 
| Message | MessageConsumer. receiveNoWait()Receives the next message if one is immediately available. | 
| void | Session. recover()Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message. | 
| Message | QueueRequestor. request(Message message)Sends a request and waits for a reply. | 
| Message | TopicRequestor. request(Message message)Sends a request and waits for a reply. | 
| void | BytesMessage. reset()Puts the message body in read-only mode and repositions the stream of bytes to the beginning. | 
| void | StreamMessage. reset()Puts the message body in read-only mode and repositions the stream to the beginning. | 
| void | Session. rollback()Rolls back any messages done in this transaction and releases any locks currently held. | 
| void | XASession. rollback()Throws a  TransactionInProgressException, since it should not be called for anXASessionobject. | 
| void | MessageProducer. send(Destination destination,
    Message message)Sends a message to a destination for an unidentified message producer using the  MessageProducer's default
 delivery mode, priority, and time to live. | 
| void | MessageProducer. send(Destination destination,
    Message message,
    CompletionListener completionListener)Sends a message to a destination for an unidentified message producer, using the  MessageProducer's default
 delivery mode, priority, and time to live, performing part of the work involved in sending the message in a separate
 thread and notifying the specified CompletionListener when the operation has completed. | 
| void | MessageProducer. send(Destination destination,
    Message message,
    int deliveryMode,
    int priority,
    long timeToLive)Sends a message to a destination for an unidentified message producer, specifying delivery mode, priority and time to
 live. | 
| void | MessageProducer. send(Destination destination,
    Message message,
    int deliveryMode,
    int priority,
    long timeToLive,
    CompletionListener completionListener)Sends a message to a destination for an unidentified message producer, specifying delivery mode, priority and time to
 live, performing part of the work involved in sending the message in a separate thread and notifying the specified
 CompletionListener when the operation has completed. | 
| void | QueueSender. send(Message message)Sends a message to the queue. | 
| void | MessageProducer. send(Message message)Sends a message using the  MessageProducer's default delivery mode, priority, and time to live. | 
| void | MessageProducer. send(Message message,
    CompletionListener completionListener)Sends a message using the  MessageProducer's default delivery mode, priority, and time to live, performing
 part of the work involved in sending the message in a separate thread and notifying the specified
 CompletionListener when the operation has completed. | 
| void | QueueSender. send(Message message,
    int deliveryMode,
    int priority,
    long timeToLive)Sends a message to the queue, specifying delivery mode, priority, and time to live. | 
| void | MessageProducer. send(Message message,
    int deliveryMode,
    int priority,
    long timeToLive)Sends a message, specifying delivery mode, priority, and time to live. | 
| void | MessageProducer. send(Message message,
    int deliveryMode,
    int priority,
    long timeToLive,
    CompletionListener completionListener)Sends a message, specifying delivery mode, priority and time to live, performing part of the work involved in sending
 the message in a separate thread and notifying the specified CompletionListener when the operation has
 completed. | 
| void | QueueSender. send(Queue queue,
    Message message)Sends a message to a queue for an unidentified message producer. | 
| void | QueueSender. send(Queue queue,
    Message message,
    int deliveryMode,
    int priority,
    long timeToLive)Sends a message to a queue for an unidentified message producer, specifying delivery mode, priority and time to live. | 
| void | MapMessage. setBoolean(String name,
          boolean value)Sets a  booleanvalue with the specified name into the Map. | 
| void | Message. setBooleanProperty(String name,
                  boolean value)Sets a  booleanproperty value with the specified name into the message. | 
| void | MapMessage. setByte(String name,
       byte value)Sets a  bytevalue with the specified name into the Map. | 
| void | Message. setByteProperty(String name,
               byte value)Sets a  byteproperty value with the specified name into the message. | 
| void | MapMessage. setBytes(String name,
        byte[] value)Sets a byte array value with the specified name into the Map. | 
| void | MapMessage. setBytes(String name,
        byte[] value,
        int offset,
        int length)Sets a portion of the byte array value with the specified name into the Map. | 
| void | MapMessage. setChar(String name,
       char value)Sets a Unicode character value with the specified name into the Map. | 
| void | Connection. setClientID(String clientID)Sets the client identifier for this connection. | 
| void | MessageProducer. setDeliveryDelay(long deliveryDelay)Sets the minimum length of time in milliseconds that must elapse after a message is sent before the Jakarta Messaging provider may
 deliver the message to a consumer. | 
| void | MessageProducer. setDeliveryMode(int deliveryMode)Sets the producer's default delivery mode. | 
| void | MessageProducer. setDisableMessageID(boolean value)Specify whether message IDs may be disabled. | 
| void | MessageProducer. setDisableMessageTimestamp(boolean value)Specify whether message timestamps may be disabled. | 
| void | MapMessage. setDouble(String name,
         double value)Sets a  doublevalue with the specified name into the Map. | 
| void | Message. setDoubleProperty(String name,
                 double value)Sets a  doubleproperty value with the specified name into the message. | 
| void | Connection. setExceptionListener(ExceptionListener listener)Sets an exception listener for this connection. | 
| void | MapMessage. setFloat(String name,
        float value)Sets a  floatvalue with the specified name into the Map. | 
| void | Message. setFloatProperty(String name,
                float value)Sets a  floatproperty value with the specified name into the message. | 
| void | MapMessage. setInt(String name,
      int value)Sets an  intvalue with the specified name into the Map. | 
| void | Message. setIntProperty(String name,
              int value)Sets an  intproperty value with the specified name into the message. | 
| void | Message. setJMSCorrelationID(String correlationID)Sets the correlation ID for the message. | 
| void | Message. setJMSCorrelationIDAsBytes(byte[] correlationID)Sets the correlation ID as an array of bytes for the message. | 
| void | Message. setJMSDeliveryMode(int deliveryMode)Sets the  DeliveryModevalue for this message. | 
| void | Message. setJMSDeliveryTime(long deliveryTime)Sets the message's delivery time value. | 
| void | Message. setJMSDestination(Destination destination)Sets the  Destinationobject for this message. | 
| void | Message. setJMSExpiration(long expiration)Sets the message's expiration value. | 
| void | Message. setJMSMessageID(String id)Sets the message ID. | 
| void | Message. setJMSPriority(int priority)Sets the priority level for this message. | 
| void | Message. setJMSRedelivered(boolean redelivered)Specifies whether this message is being redelivered. | 
| void | Message. setJMSReplyTo(Destination replyTo)Sets the  Destinationobject to which a reply to this message should be sent. | 
| void | Message. setJMSTimestamp(long timestamp)Sets the message timestamp. | 
| void | Message. setJMSType(String type)Sets the message type. | 
| void | MapMessage. setLong(String name,
       long value)Sets a  longvalue with the specified name into the Map. | 
| void | Message. setLongProperty(String name,
               long value)Sets a  longproperty value with the specified name into the message. | 
| void | Session. setMessageListener(MessageListener listener)Sets the session's distinguished message listener (optional). | 
| void | MessageConsumer. setMessageListener(MessageListener listener)Sets the  MessageConsumer'sMessageListener. | 
| void | ObjectMessage. setObject(Serializable object)Sets the serializable object containing this message's data. | 
| void | MapMessage. setObject(String name,
         Object value)Sets an object value with the specified name into the Map. | 
| void | Message. setObjectProperty(String name,
                 Object value)Sets a Java object property value with the specified name into the message. | 
| void | MessageProducer. setPriority(int defaultPriority)Sets the producer's default priority. | 
| void | MapMessage. setShort(String name,
        short value)Sets a  shortvalue with the specified name into the Map. | 
| void | Message. setShortProperty(String name,
                short value)Sets a  shortproperty value with the specified name into the message. | 
| void | MapMessage. setString(String name,
         String value)Sets a  Stringvalue with the specified name into the Map. | 
| void | Message. setStringProperty(String name,
                 String value)Sets a  Stringproperty value with the specified name into the message. | 
| void | TextMessage. setText(String string)Sets the string containing this message's data. | 
| void | MessageProducer. setTimeToLive(long timeToLive)Sets the default length of time in milliseconds from its dispatch time that a produced message should be retained by
 the message system. | 
| void | Connection. start()Starts (or restarts) a connection's delivery of incoming messages. | 
| void | ServerSession. start()Cause the  Session'srunmethod to be called to process messages that were just assigned to it. | 
| void | Connection. stop()Temporarily stops a connection's delivery of incoming messages. | 
| void | Session. unsubscribe(String name)Unsubscribes a durable subscription that has been created by a client. | 
| void | TopicSession. unsubscribe(String name)Unsubscribes a durable subscription that has been created by a client. | 
| void | BytesMessage. writeBoolean(boolean value)Writes a  booleanto the bytes message stream as a 1-byte value. | 
| void | StreamMessage. writeBoolean(boolean value)Writes a  booleanto the stream message. | 
| void | BytesMessage. writeByte(byte value)Writes a  byteto the bytes message stream as a 1-byte value. | 
| void | StreamMessage. writeByte(byte value)Writes a  byteto the stream message. | 
| void | BytesMessage. writeBytes(byte[] value)Writes a byte array to the bytes message stream. | 
| void | StreamMessage. writeBytes(byte[] value)Writes a byte array field to the stream message. | 
| void | BytesMessage. writeBytes(byte[] value,
          int offset,
          int length)Writes a portion of a byte array to the bytes message stream. | 
| void | StreamMessage. writeBytes(byte[] value,
          int offset,
          int length)Writes a portion of a byte array as a byte array field to the stream message. | 
| void | BytesMessage. writeChar(char value)Writes a  charto the bytes message stream as a 2-byte value, high byte first. | 
| void | StreamMessage. writeChar(char value)Writes a  charto the stream message. | 
| void | BytesMessage. writeDouble(double value)Converts the  doubleargument to alongusing thedoubleToLongBitsmethod in classDouble, and then writes thatlongvalue to the bytes message stream as an 8-byte quantity, high byte
 first. | 
| void | StreamMessage. writeDouble(double value)Writes a  doubleto the stream message. | 
| void | BytesMessage. writeFloat(float value)Converts the  floatargument to anintusing thefloatToIntBitsmethod in classFloat,
 and then writes thatintvalue to the bytes message stream as a 4-byte quantity, high byte first. | 
| void | StreamMessage. writeFloat(float value)Writes a  floatto the stream message. | 
| void | BytesMessage. writeInt(int value)Writes an  intto the bytes message stream as four bytes, high byte first. | 
| void | StreamMessage. writeInt(int value)Writes an  intto the stream message. | 
| void | BytesMessage. writeLong(long value)Writes a  longto the bytes message stream as eight bytes, high byte first. | 
| void | StreamMessage. writeLong(long value)Writes a  longto the stream message. | 
| void | BytesMessage. writeObject(Object value)Writes an object to the bytes message stream. | 
| void | StreamMessage. writeObject(Object value)Writes an object to the stream message. | 
| void | BytesMessage. writeShort(short value)Writes a  shortto the bytes message stream as two bytes, high byte first. | 
| void | StreamMessage. writeShort(short value)Writes a  shortto the stream message. | 
| void | StreamMessage. writeString(String value)Writes a  Stringto the stream message. | 
| void | BytesMessage. writeUTF(String value)Writes a string to the bytes message stream using UTF-8 encoding in a machine-independent manner. | 
| Constructor and Description | 
|---|
| QueueRequestor(QueueSession session,
              Queue queue)Constructor for the  QueueRequestorclass. | 
| TopicRequestor(TopicSession session,
              Topic topic)Constructor for the  TopicRequestorclass. | 
Comments to: jms-dev@eclipse.org.
 Copyright © 2018, 2020 Eclipse Foundation. All rights reserved.
 Use is subject to license terms.