|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use JMSException | |
javax.jms |
Uses of JMSException in javax.jms |
Subclasses of JMSException in javax.jms | |
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 is either not understood by a provider or is no longer valid. |
class |
InvalidSelectorException
This exception must be thrown when a JMS client attempts to give a provider a message selector with invalid syntax. |
class |
JMSSecurityException
This exception must be thrown when a provider rejects a user name/password submitted by a client. |
class |
MessageEOFException
This exception must be thrown when an unexpected end of stream has been reached when a StreamMessage or BytesMessage is being read. |
class |
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. |
class |
MessageNotReadableException
This exception must be thrown when a JMS client attempts to read a write-only message. |
class |
MessageNotWriteableException
This exception must be thrown when a JMS client attempts to write to a read-only message. |
class |
ResourceAllocationException
This exception is thrown when a provider is unable to allocate the resources required by a method. |
class |
TransactionInProgressException
This exception is thrown when an operation is invalid because a transaction is in progress. |
class |
TransactionRolledBackException
This exception must be thrown when a call to Session.commit results in a rollback of the current transaction. |
Methods in javax.jms with parameters of type JMSException | |
void |
ExceptionListener.onException(JMSException exception)
Notify user of a JMS exception. |
Methods in javax.jms that throw JMSException | |
XAQueueConnection |
XAQueueConnectionFactory.createXAQueueConnection()
Create an XA queue connection with default user identity. |
XAQueueConnection |
XAQueueConnectionFactory.createXAQueueConnection(String userName,
String password)
Create an XA queue connection with specific user identity. |
Topic |
TopicSession.createTopic(String topicName)
Create a topic identity given a Topic name. |
TopicSubscriber |
TopicSession.createSubscriber(Topic topic)
Create a non-durable Subscriber to the specified topic. |
TopicSubscriber |
TopicSession.createSubscriber(Topic topic,
String messageSelector,
boolean noLocal)
Create a non-durable Subscriber to the specified topic. |
TopicSubscriber |
TopicSession.createDurableSubscriber(Topic topic,
String name)
Create a durable Subscriber to the specified topic. |
TopicSubscriber |
TopicSession.createDurableSubscriber(Topic topic,
String name,
String messageSelector,
boolean noLocal)
Create a durable Subscriber to the specified topic. |
TopicPublisher |
TopicSession.createPublisher(Topic topic)
Create a Publisher for the specified topic. |
TemporaryTopic |
TopicSession.createTemporaryTopic()
Create a temporary topic. |
void |
TopicSession.unsubscribe(String name)
Unsubscribe a durable subscription that has been created by a client. |
Message |
QueueRequestor.request(Message message)
Send a request and wait for a reply. |
void |
QueueRequestor.close()
Since a provider may allocate some resources on behalf of a QueueRequestor outside the JVM, clients should close them when they are not needed. |
void |
TemporaryQueue.delete()
Delete this temporary queue. |
Message |
TopicRequestor.request(Message message)
Send a request and wait for a reply. |
void |
TopicRequestor.close()
Since a provider may allocate some resources on behalf of a TopicRequestor outside the JVM, clients should close them when they are not needed. |
Queue |
QueueBrowser.getQueue()
Get the queue associated with this queue browser. |
String |
QueueBrowser.getMessageSelector()
Get this queue browser's message selector expression. |
Enumeration |
QueueBrowser.getEnumeration()
Get an enumeration for browsing the current queue messages in the order they would be received. |
void |
QueueBrowser.close()
Since a provider may allocate some resources on behalf of a QueueBrowser outside the JVM, clients should close them when they are not needed. |
TopicSession |
XATopicSession.getTopicSession()
Get the topic session associated with this XATopicSession. |
String |
ConnectionMetaData.getJMSVersion()
Get the JMS version. |
int |
ConnectionMetaData.getJMSMajorVersion()
Get the JMS major version number. |
int |
ConnectionMetaData.getJMSMinorVersion()
Get the JMS minor version number. |
String |
ConnectionMetaData.getJMSProviderName()
Get the JMS provider name. |
String |
ConnectionMetaData.getProviderVersion()
Get the JMS provider version. |
int |
ConnectionMetaData.getProviderMajorVersion()
Get the JMS provider major version number. |
int |
ConnectionMetaData.getProviderMinorVersion()
Get the JMS provider minor version number. |
Enumeration |
ConnectionMetaData.getJMSXPropertyNames()
Get an enumeration of JMSX Property Names. |
BytesMessage |
Session.createBytesMessage()
Create a BytesMessage. |
MapMessage |
Session.createMapMessage()
Create a MapMessage. |
Message |
Session.createMessage()
Create a Message. |
ObjectMessage |
Session.createObjectMessage()
Create an ObjectMessage. |
ObjectMessage |
Session.createObjectMessage(Serializable object)
Create an initialized ObjectMessage. |
StreamMessage |
Session.createStreamMessage()
Create a StreamMessage. |
TextMessage |
Session.createTextMessage()
Create a TextMessage. |
TextMessage |
Session.createTextMessage(String text)
Create an initialized TextMessage. |
boolean |
Session.getTransacted()
Is the session in transacted mode? |
void |
Session.commit()
Commit all messages done in this transaction and releases any locks currently held. |
void |
Session.rollback()
Rollback any messages done in this transaction and releases any locks currently held. |
void |
Session.close()
Since a provider may allocate some resources on behalf of a Session outside the JVM, clients should close them when they are not needed. |
void |
Session.recover()
Stop message delivery in this session, and restart sending messages with the oldest unacknowledged message. |
MessageListener |
Session.getMessageListener()
Return the session's distinguished message listener (optional). |
void |
Session.setMessageListener(MessageListener listener)
Set the session's distinguished message listener (optional). |
Queue |
QueueReceiver.getQueue()
Get the queue associated with this queue receiver. |
ServerSessionPool |
ConnectionConsumer.getServerSessionPool()
Get the server session pool associated with this connection consumer. |
void |
ConnectionConsumer.close()
Since a provider may allocate some resources on behalf of a ConnectionConsumer outside the JVM, clients should close them when they are not needed. |
void |
TextMessage.setText(String string)
Set the string containing this message's data. |
String |
TextMessage.getText()
Get the string containing this message's data. |
String |
Connection.getClientID()
Get the client identifier for this connection. |
void |
Connection.setClientID(String clientID)
Set the client identifier for this connection. |
ConnectionMetaData |
Connection.getMetaData()
Get the meta data for this connection. |
ExceptionListener |
Connection.getExceptionListener()
Get the ExceptionListener for this Connection. |
void |
Connection.setExceptionListener(ExceptionListener listener)
Set an exception listener for this connection. |
void |
Connection.start()
Start (or restart) a Connection's delivery of incoming messages. |
void |
Connection.stop()
Used to temporarily stop a Connection's delivery of incoming messages. |
void |
Connection.close()
Since a provider typically allocates significant resources outside the JVM on behalf of a Connection, clients should close them when they are not needed. |
Session |
ServerSession.getSession()
Return the ServerSession's Session. |
void |
ServerSession.start()
Cause the session's run method to be called to process messages that were just assigned to it. |
QueueSession |
QueueConnection.createQueueSession(boolean transacted,
int acknowledgeMode)
Create a QueueSession. |
ConnectionConsumer |
QueueConnection.createConnectionConsumer(Queue queue,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Create a connection consumer for this connection (optional operation). |
String |
MessageConsumer.getMessageSelector()
Get this message consumer's message selector expression. |
MessageListener |
MessageConsumer.getMessageListener()
Get the message consumer's MessageListener. |
void |
MessageConsumer.setMessageListener(MessageListener listener)
Set the message consumer's MessageListener. |
Message |
MessageConsumer.receive()
Receive the next message produced for this message consumer. |
Message |
MessageConsumer.receive(long timeout)
Receive the next message that arrives within the specified timeout interval. |
Message |
MessageConsumer.receiveNoWait()
Receive the next message if one is immediately available. |
void |
MessageConsumer.close()
Since a provider may allocate some resources on behalf of a MessageConsumer outside the JVM, clients should close them when they are not needed. |
boolean |
MapMessage.getBoolean(String name)
Return the boolean value with the given name. |
byte |
MapMessage.getByte(String name)
Return the byte value with the given name. |
short |
MapMessage.getShort(String name)
Return the short value with the given name. |
char |
MapMessage.getChar(String name)
Return the Unicode character value with the given name. |
int |
MapMessage.getInt(String name)
Return the integer value with the given name. |
long |
MapMessage.getLong(String name)
Return the long value with the given name. |
float |
MapMessage.getFloat(String name)
Return the float value with the given name. |
double |
MapMessage.getDouble(String name)
Return the double value with the given name. |
String |
MapMessage.getString(String name)
Return the String value with the given name. |
byte[] |
MapMessage.getBytes(String name)
Return the byte array value with the given name. |
Object |
MapMessage.getObject(String name)
Return the Java object value with the given name. |
Enumeration |
MapMessage.getMapNames()
Return an Enumeration of all the Map message's names. |
void |
MapMessage.setBoolean(String name,
boolean value)
Set a boolean value with the given name, into the Map. |
void |
MapMessage.setByte(String name,
byte value)
Set a byte value with the given name, into the Map. |
void |
MapMessage.setShort(String name,
short value)
Set a short value with the given name, into the Map. |
void |
MapMessage.setChar(String name,
char value)
Set a Unicode character value with the given name, into the Map. |
void |
MapMessage.setInt(String name,
int value)
Set an integer value with the given name, into the Map. |
void |
MapMessage.setLong(String name,
long value)
Set a long value with the given name, into the Map. |
void |
MapMessage.setFloat(String name,
float value)
Set a float value with the given name, into the Map. |
void |
MapMessage.setDouble(String name,
double value)
Set a double value with the given name, into the Map. |
void |
MapMessage.setString(String name,
String value)
Set a String value with the given name, into the Map. |
void |
MapMessage.setBytes(String name,
byte[] value)
Set a byte array value with the given name, into the Map. |
void |
MapMessage.setBytes(String name,
byte[] value,
int offset,
int length)
Set a portion of the byte array value with the given name, into the Map. |
void |
MapMessage.setObject(String name,
Object value)
Set a Java object value with the given name, into the Map. |
boolean |
MapMessage.itemExists(String name)
Check if an item exists in this MapMessage. |
Topic |
TopicSubscriber.getTopic()
Get the topic associated with this subscriber. |
boolean |
TopicSubscriber.getNoLocal()
Get the NoLocal attribute for this TopicSubscriber. |
XATopicSession |
XATopicConnection.createXATopicSession()
Create an XATopicSession. |
TopicSession |
XATopicConnection.createTopicSession(boolean transacted,
int acknowledgeMode)
Create an XATopicSession |
TopicConnection |
TopicConnectionFactory.createTopicConnection()
Create a topic connection with default user identity. |
TopicConnection |
TopicConnectionFactory.createTopicConnection(String userName,
String password)
Create a topic connection with specified user identity. |
void |
ObjectMessage.setObject(Serializable object)
Set the serializable object containing this message's data. |
Serializable |
ObjectMessage.getObject()
Get the serializable object containing this message's data. |
String |
Topic.getTopicName()
Get the name of this topic. |
boolean |
XASession.getTransacted()
Is the session in transacted mode? |
void |
XASession.commit()
Throws TransactionInProgressException since it should not be called for an XASession object. |
void |
XASession.rollback()
Throws TransactionInProgressException since it should not be called for an XASession object. |
XATopicConnection |
XATopicConnectionFactory.createXATopicConnection()
Create an XA topic connection with default user identity. |
XATopicConnection |
XATopicConnectionFactory.createXATopicConnection(String userName,
String password)
Create an XA topic connection with specified user identity. |
String |
Message.getJMSMessageID()
Get the message ID. |
void |
Message.setJMSMessageID(String id)
Set the message ID. |
long |
Message.getJMSTimestamp()
Get the message timestamp. |
void |
Message.setJMSTimestamp(long timestamp)
Set the message timestamp. |
byte[] |
Message.getJMSCorrelationIDAsBytes()
Get the correlation ID as an array of bytes for the message. |
void |
Message.setJMSCorrelationIDAsBytes(byte[] correlationID)
Set the correlation ID as an array of bytes for the message. |
void |
Message.setJMSCorrelationID(String correlationID)
Set the correlation ID for the message. |
String |
Message.getJMSCorrelationID()
Get the correlation ID for the message. |
Destination |
Message.getJMSReplyTo()
Get where a reply to this message should be sent. |
void |
Message.setJMSReplyTo(Destination replyTo)
Set where a reply to this message should be sent. |
Destination |
Message.getJMSDestination()
Get the destination for this message. |
void |
Message.setJMSDestination(Destination destination)
Set the destination for this message. |
int |
Message.getJMSDeliveryMode()
Get the delivery mode for this message. |
void |
Message.setJMSDeliveryMode(int deliveryMode)
Set the delivery mode for this message. |
boolean |
Message.getJMSRedelivered()
Get an indication of whether this message is being redelivered. |
void |
Message.setJMSRedelivered(boolean redelivered)
Set to indicate whether this message is being redelivered. |
String |
Message.getJMSType()
Get the message type. |
void |
Message.setJMSType(String type)
Set the message type. |
long |
Message.getJMSExpiration()
Get the message's expiration value. |
void |
Message.setJMSExpiration(long expiration)
Set the message's expiration value. |
int |
Message.getJMSPriority()
Get the message priority. |
void |
Message.setJMSPriority(int priority)
Set the priority for this message. |
void |
Message.clearProperties()
Clear a message's properties. |
boolean |
Message.propertyExists(String name)
Check if a property value exists. |
boolean |
Message.getBooleanProperty(String name)
Return the boolean property value with the given name. |
byte |
Message.getByteProperty(String name)
Return the byte property value with the given name. |
short |
Message.getShortProperty(String name)
Return the short property value with the given name. |
int |
Message.getIntProperty(String name)
Return the integer property value with the given name. |
long |
Message.getLongProperty(String name)
Return the long property value with the given name. |
float |
Message.getFloatProperty(String name)
Return the float property value with the given name. |
double |
Message.getDoubleProperty(String name)
Return the double property value with the given name. |
String |
Message.getStringProperty(String name)
Return the String property value with the given name. |
Object |
Message.getObjectProperty(String name)
Return the Java object property value with the given name. |
Enumeration |
Message.getPropertyNames()
Return an Enumeration of all the property names. |
void |
Message.setBooleanProperty(String name,
boolean value)
Set a boolean property value with the given name, into the Message. |
void |
Message.setByteProperty(String name,
byte value)
Set a byte property value with the given name, into the Message. |
void |
Message.setShortProperty(String name,
short value)
Set a short property value with the given name, into the Message. |
void |
Message.setIntProperty(String name,
int value)
Set an integer property value with the given name, into the Message. |
void |
Message.setLongProperty(String name,
long value)
Set a long property value with the given name, into the Message. |
void |
Message.setFloatProperty(String name,
float value)
Set a float property value with the given name, into the Message. |
void |
Message.setDoubleProperty(String name,
double value)
Set a double property value with the given name, into the Message. |
void |
Message.setStringProperty(String name,
String value)
Set a String property value with the given name, into the Message. |
void |
Message.setObjectProperty(String name,
Object value)
Set a Java object property value with the given name, into the Message. |
void |
Message.acknowledge()
Acknowledge this and all previous messages received. |
void |
Message.clearBody()
Clear out the message body. |
void |
MessageProducer.setDisableMessageID(boolean value)
Set whether message IDs are disabled. |
boolean |
MessageProducer.getDisableMessageID()
Get an indication of whether message IDs are disabled. |
void |
MessageProducer.setDisableMessageTimestamp(boolean value)
Set whether message timestamps are disabled. |
boolean |
MessageProducer.getDisableMessageTimestamp()
Get an indication of whether message timestamps are disabled. |
void |
MessageProducer.setDeliveryMode(int deliveryMode)
Set the producer's default delivery mode. |
int |
MessageProducer.getDeliveryMode()
Get the producer's default delivery mode. |
void |
MessageProducer.setPriority(int defaultPriority)
Set the producer's default priority. |
int |
MessageProducer.getPriority()
Get the producer's default priority. |
void |
MessageProducer.setTimeToLive(long timeToLive)
Set the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system. |
long |
MessageProducer.getTimeToLive()
Get the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system. |
void |
MessageProducer.close()
Since a provider may allocate some resources on behalf of a MessageProducer outside the JVM, clients should close them when they are not needed. |
boolean |
BytesMessage.readBoolean()
Read a boolean from the bytes message stream. |
byte |
BytesMessage.readByte()
Read a signed 8-bit value from the bytes message stream. |
int |
BytesMessage.readUnsignedByte()
Read an unsigned 8-bit number from the bytes message stream. |
short |
BytesMessage.readShort()
Read a signed 16-bit number from the bytes message stream. |
int |
BytesMessage.readUnsignedShort()
Read an unsigned 16-bit number from the bytes message stream. |
char |
BytesMessage.readChar()
Read a Unicode character value from the bytes message stream. |
int |
BytesMessage.readInt()
Read a signed 32-bit integer from the bytes message stream. |
long |
BytesMessage.readLong()
Read a signed 64-bit integer from the bytes message stream. |
float |
BytesMessage.readFloat()
Read a float from the bytes message stream. |
double |
BytesMessage.readDouble()
Read a double from the bytes message stream. |
String |
BytesMessage.readUTF()
Read in a string that has been encoded using a modified UTF-8 format from the bytes message stream. |
int |
BytesMessage.readBytes(byte[] value)
Read a byte array from the bytes message stream. |
int |
BytesMessage.readBytes(byte[] value,
int length)
Read a portion of the bytes message stream. |
void |
BytesMessage.writeBoolean(boolean value)
Write a boolean to the bytes message stream as a 1-byte value. |
void |
BytesMessage.writeByte(byte value)
Write out a byte to the bytes message stream as a 1-byte value. |
void |
BytesMessage.writeShort(short value)
Write a short to the bytes message stream as two bytes, high
byte first. |
void |
BytesMessage.writeChar(char value)
Write a char to the bytes message stream as a 2-byte value,
high byte first. |
void |
BytesMessage.writeInt(int value)
Write an int to the bytes message stream as four bytes,
high byte first. |
void |
BytesMessage.writeLong(long value)
Write a long to the bytes message stream as eight bytes,
high byte first. |
void |
BytesMessage.writeFloat(float value)
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. |
void |
BytesMessage.writeDouble(double value)
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. |
void |
BytesMessage.writeUTF(String value)
Write a string to the bytes message stream using UTF-8 encoding in a machine-independent manner. |
void |
BytesMessage.writeBytes(byte[] value)
Write a byte array to the bytes message stream. |
void |
BytesMessage.writeBytes(byte[] value,
int offset,
int length)
Write a portion of a byte array to the bytes message stream. |
void |
BytesMessage.writeObject(Object value)
Write a Java object to the bytes message stream. |
void |
BytesMessage.reset()
Put the message body in read-only mode, and reposition the stream of bytes to the beginning. |
Topic |
TopicPublisher.getTopic()
Get the topic associated with this publisher. |
void |
TopicPublisher.publish(Message message)
Publish a Message to the topic Use the topics default delivery mode, timeToLive and priority. |
void |
TopicPublisher.publish(Message message,
int deliveryMode,
int priority,
long timeToLive)
Publish a Message to the topic specifying delivery mode, priority and time to live to the topic. |
void |
TopicPublisher.publish(Topic topic,
Message message)
Publish a Message to a topic for an unidentified message producer. |
void |
TopicPublisher.publish(Topic topic,
Message message,
int deliveryMode,
int priority,
long timeToLive)
Publish a Message to a topic for an unidentified message producer, specifying delivery mode, priority and time to live. |
String |
Queue.getQueueName()
Get the name of this queue. |
boolean |
StreamMessage.readBoolean()
Read a boolean from the stream message. |
byte |
StreamMessage.readByte()
Read a byte value from the stream message. |
short |
StreamMessage.readShort()
Read a 16-bit number from the stream message. |
char |
StreamMessage.readChar()
Read a Unicode character value from the stream message. |
int |
StreamMessage.readInt()
Read a 32-bit integer from the stream message. |
long |
StreamMessage.readLong()
Read a 64-bit integer from the stream message. |
float |
StreamMessage.readFloat()
Read a float from the stream message. |
double |
StreamMessage.readDouble()
Read a double from the stream message. |
String |
StreamMessage.readString()
Read in a string from the stream message. |
int |
StreamMessage.readBytes(byte[] value)
Read a byte array field from the stream message into the specified byte[] object (the read buffer). |
Object |
StreamMessage.readObject()
Read a Java object from the stream message. |
void |
StreamMessage.writeBoolean(boolean value)
Write a boolean to the stream message. |
void |
StreamMessage.writeByte(byte value)
Write out a byte to the stream message. |
void |
StreamMessage.writeShort(short value)
Write a short to the stream message. |
void |
StreamMessage.writeChar(char value)
Write a char to the stream message. |
void |
StreamMessage.writeInt(int value)
Write an int to the stream message. |
void |
StreamMessage.writeLong(long value)
Write a long to the stream message. |
void |
StreamMessage.writeFloat(float value)
Write a float to the stream message. |
void |
StreamMessage.writeDouble(double value)
Write a double to the stream message. |
void |
StreamMessage.writeString(String value)
Write a string to the stream message. |
void |
StreamMessage.writeBytes(byte[] value)
Write a byte array field to the stream message. |
void |
StreamMessage.writeBytes(byte[] value,
int offset,
int length)
Write a portion of a byte array as a byte array field to the stream message. |
void |
StreamMessage.writeObject(Object value)
Write a Java object to the stream message. |
void |
StreamMessage.reset()
Put the message body in read-only mode, and reposition the stream to the beginning. |
ServerSession |
ServerSessionPool.getServerSession()
Return a server session from the pool. |
XAQueueSession |
XAQueueConnection.createXAQueueSession()
Create an XAQueueSession. |
QueueSession |
XAQueueConnection.createQueueSession(boolean transacted,
int acknowledgeMode)
Create an XAQueueSession. |
QueueConnection |
QueueConnectionFactory.createQueueConnection()
Create a queue connection with default user identity. |
QueueConnection |
QueueConnectionFactory.createQueueConnection(String userName,
String password)
Create a queue connection with specified user identity. |
Queue |
QueueSession.createQueue(String queueName)
Create a queue identity given a Queue name. |
QueueReceiver |
QueueSession.createReceiver(Queue queue)
Create a QueueReceiver to receive messages from the specified queue. |
QueueReceiver |
QueueSession.createReceiver(Queue queue,
String messageSelector)
Create a QueueReceiver to receive messages from the specified queue. |
QueueSender |
QueueSession.createSender(Queue queue)
Create a QueueSender to send messages to the specified queue. |
QueueBrowser |
QueueSession.createBrowser(Queue queue)
Create a QueueBrowser to peek at the messages on the specified queue. |
QueueBrowser |
QueueSession.createBrowser(Queue queue,
String messageSelector)
Create a QueueBrowser to peek at the messages on the specified queue. |
TemporaryQueue |
QueueSession.createTemporaryQueue()
Create a temporary queue. |
void |
TemporaryTopic.delete()
Delete this temporary topic. |
QueueSession |
XAQueueSession.getQueueSession()
Get the queue session associated with this XAQueueSession. |
TopicSession |
TopicConnection.createTopicSession(boolean transacted,
int acknowledgeMode)
Create a TopicSession |
ConnectionConsumer |
TopicConnection.createConnectionConsumer(Topic topic,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Create a connection consumer for this connection (optional operation). |
ConnectionConsumer |
TopicConnection.createDurableConnectionConsumer(Topic topic,
String subscriptionName,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Create a durable connection consumer for this connection (optional operation). |
Queue |
QueueSender.getQueue()
Get the queue associated with this queue sender. |
void |
QueueSender.send(Message message)
Send a message to the queue. |
void |
QueueSender.send(Message message,
int deliveryMode,
int priority,
long timeToLive)
Send a message specifying delivery mode, priority and time to live to the queue. |
void |
QueueSender.send(Queue queue,
Message message)
Send a message to a queue for an unidentified message producer. |
void |
QueueSender.send(Queue queue,
Message message,
int deliveryMode,
int priority,
long timeToLive)
Send a message to a queue for an unidentified message producer, specifying delivery mode, priority and time to live. |
Constructors in javax.jms that throw JMSException | |
QueueRequestor(QueueSession session,
Queue queue)
Constructor for the QueueRequestor class. |
|
TopicRequestor(TopicSession session,
Topic topic)
Constructor for the TopicRequestor class. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |