Package | Description |
---|---|
javax.jms |
The Java Message Service (JMS) API provides a common way for Java programs to create, send, receive and read an enterprise messaging system's messages.
|
org.apache.activemq.artemis.api.jms.management | |
org.apache.activemq.artemis.jms.client |
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
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. |
Modifier and Type | Method and Description |
---|---|
void |
ExceptionListener.onException(JMSException exception)
Notifies user of a JMS 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 |
TopicRequestor.close()
Closes the
TopicRequestor and its session. |
void |
Session.close()
Closes the session.
|
void |
QueueRequestor.close()
Closes the
QueueRequestor and its session. |
void |
QueueBrowser.close()
Closes the
QueueBrowser . |
void |
MessageProducer.close()
Closes the message producer.
|
void |
MessageConsumer.close()
Closes the message consumer.
|
void |
ConnectionConsumer.close()
Closes the connection consumer.
|
void |
Connection.close()
Closes the connection.
|
void |
XASession.commit()
Throws a
TransactionInProgressException , since it should
not be called for an XASession object. |
void |
Session.commit()
Commits all messages done in this transaction and releases any locks
currently held.
|
QueueBrowser |
Session.createBrowser(Queue queue)
Creates a
QueueBrowser object to peek at the messages on
the specified queue. |
QueueBrowser |
QueueSession.createBrowser(Queue queue)
Creates a
QueueBrowser object to peek at the messages on
the specified queue. |
QueueBrowser |
Session.createBrowser(Queue queue,
String messageSelector)
Creates a
QueueBrowser object to peek at the messages on the
specified queue using a message selector. |
QueueBrowser |
QueueSession.createBrowser(Queue queue,
String messageSelector)
Creates a
QueueBrowser object to peek at the messages on
the specified queue using a message selector. |
BytesMessage |
Session.createBytesMessage()
Creates a
BytesMessage object. |
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
MessageConsumer for the specified destination. |
MessageConsumer |
Session.createConsumer(Destination destination,
String messageSelector)
Creates a
MessageConsumer for the specified destination,
using a message selector. |
MessageConsumer |
Session.createConsumer(Destination destination,
String messageSelector,
boolean noLocal)
Creates a
MessageConsumer for the specified destination, specifying a
message selector and the noLocal parameter. |
ConnectionConsumer |
TopicConnection.createDurableConnectionConsumer(Topic topic,
String subscriptionName,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Create a durable connection consumer for this connection (optional operation).
|
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.
|
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
noLocal parameter, 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)
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,
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
noLocal parameter, 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
noLocal parameter, and creates a consumer on that durable
subscription. |
MapMessage |
Session.createMapMessage()
Creates a
MapMessage object. |
Message |
Session.createMessage()
Creates a
Message object. |
ObjectMessage |
Session.createObjectMessage()
Creates an
ObjectMessage object. |
ObjectMessage |
Session.createObjectMessage(Serializable object)
Creates an initialized
ObjectMessage object. |
MessageProducer |
Session.createProducer(Destination destination)
Creates a
MessageProducer to 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
Queue object which encapsulates a specified
provider-specific queue name. |
Queue |
QueueSession.createQueue(String queueName)
Creates a queue identity given a
Queue name. |
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 |
XAQueueConnection.createQueueSession(boolean transacted,
int acknowledgeMode)
Creates a
QueueSession object. |
QueueSession |
QueueConnection.createQueueSession(boolean transacted,
int acknowledgeMode)
Creates a
QueueSession object. |
QueueReceiver |
QueueSession.createReceiver(Queue queue)
Creates a
QueueReceiver object to receive messages from the
specified queue. |
QueueReceiver |
QueueSession.createReceiver(Queue queue,
String messageSelector)
Creates a
QueueReceiver object to receive messages from the
specified queue using a message selector. |
QueueSender |
QueueSession.createSender(Queue queue)
Creates a
QueueSender object to send messages to the
specified queue. |
Session |
Connection.createSession()
Creates a
Session object,
specifying no arguments. |
Session |
XAConnection.createSession(boolean transacted,
int acknowledgeMode)
Creates an
Session object. |
Session |
Connection.createSession(boolean transacted,
int acknowledgeMode)
Creates a
Session object,
specifying transacted and acknowledgeMode . |
Session |
Connection.createSession(int sessionMode)
Creates a
Session object, specifying sessionMode . |
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
noLocal
parameter, 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
StreamMessage object. |
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
TemporaryQueue object. |
TemporaryQueue |
QueueSession.createTemporaryQueue()
Creates a
TemporaryQueue object. |
TemporaryTopic |
TopicSession.createTemporaryTopic()
Creates a
TemporaryTopic object. |
TemporaryTopic |
Session.createTemporaryTopic()
Creates a
TemporaryTopic object. |
TextMessage |
Session.createTextMessage()
Creates a
TextMessage object. |
TextMessage |
Session.createTextMessage(String text)
Creates an initialized
TextMessage object. |
Topic |
TopicSession.createTopic(String topicName)
Creates a topic identity given a
Topic name. |
Topic |
Session.createTopic(String topicName)
Creates a
Topic object which encapsulates a specified
provider-specific topic name. |
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
TopicSession object. |
TopicSession |
TopicConnection.createTopicSession(boolean transacted,
int acknowledgeMode)
Creates a
TopicSession object. |
XAConnection |
XAConnectionFactory.createXAConnection()
Creates an
XAConnection with the default user identity. |
XAConnection |
XAConnectionFactory.createXAConnection(String userName,
String password)
Creates an
XAConnection with 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
XAQueueSession object. |
XASession |
XAConnection.createXASession()
Creates an
XASession object. |
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
XATopicSession object. |
void |
TemporaryTopic.delete()
Deletes this temporary topic.
|
void |
TemporaryQueue.delete()
Deletes this temporary queue.
|
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
boolean value with the specified name. |
boolean |
Message.getBooleanProperty(String name)
Returns the value of the
boolean property with the
specified name. |
byte |
MapMessage.getByte(String name)
Returns the
byte value with the specified name. |
byte |
Message.getByteProperty(String name)
Returns the value of the
byte property 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 JMS 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
double value with the specified name. |
double |
Message.getDoubleProperty(String name)
Returns the value of the
double property 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
ExceptionListener object for this connection. |
float |
MapMessage.getFloat(String name)
Returns the
float value with the specified name. |
float |
Message.getFloatProperty(String name)
Returns the value of the
float property with the specified
name. |
int |
MapMessage.getInt(String name)
Returns the
int value with the specified name. |
int |
Message.getIntProperty(String name)
Returns the value of the
int property 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
DeliveryMode value specified for this message. |
long |
Message.getJMSDeliveryTime()
Gets the message's delivery time value.
|
Destination |
Message.getJMSDestination()
Gets the
Destination object for this message. |
long |
Message.getJMSExpiration()
Gets the message's expiration time.
|
int |
ConnectionMetaData.getJMSMajorVersion()
Gets the JMS major version number.
|
String |
Message.getJMSMessageID()
Gets the message ID.
|
int |
ConnectionMetaData.getJMSMinorVersion()
Gets the JMS minor version number.
|
int |
Message.getJMSPriority()
Gets the message priority level.
|
String |
ConnectionMetaData.getJMSProviderName()
Gets the JMS provider name.
|
boolean |
Message.getJMSRedelivered()
Gets an indication of whether this message is being redelivered.
|
Destination |
Message.getJMSReplyTo()
Gets the
Destination object 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 JMS API version.
|
Enumeration |
ConnectionMetaData.getJMSXPropertyNames()
Gets an enumeration of the JMSX property names.
|
long |
MapMessage.getLong(String name)
Returns the
long value with the specified name. |
long |
Message.getLongProperty(String name)
Returns the value of the
long property with the specified
name. |
Enumeration |
MapMessage.getMapNames()
Returns an
Enumeration of all the names in the
MapMessage object. |
MessageListener |
Session.getMessageListener()
Returns the session's distinguished message listener (optional).
|
MessageListener |
MessageConsumer.getMessageListener()
Gets the
MessageConsumer 's MessageListener . |
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
NoLocal attribute 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
Enumeration of all the property names. |
int |
ConnectionMetaData.getProviderMajorVersion()
Gets the JMS provider major version number.
|
int |
ConnectionMetaData.getProviderMinorVersion()
Gets the JMS provider minor version number.
|
String |
ConnectionMetaData.getProviderVersion()
Gets the JMS provider version.
|
Queue |
QueueSender.getQueue()
Gets the queue associated with this
QueueSender . |
Queue |
QueueReceiver.getQueue()
Gets the
Queue associated with this queue receiver. |
Queue |
QueueBrowser.getQueue()
Gets the queue associated with this queue browser.
|
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 's Session . |
short |
MapMessage.getShort(String name)
Returns the
short value with the specified name. |
short |
Message.getShortProperty(String name)
Returns the value of the
short property with the specified
name. |
String |
MapMessage.getString(String name)
Returns the
String value with the specified name. |
String |
Message.getStringProperty(String name)
Returns the value of the
String property 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
Topic associated 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 |
XASession.getTransacted()
Indicates whether the session is in transacted mode.
|
boolean |
Session.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
MapMessage object. |
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 |
StreamMessage.readBoolean()
Reads a
boolean from the stream message. |
boolean |
BytesMessage.readBoolean()
Reads a
boolean from the bytes message stream. |
byte |
StreamMessage.readByte()
Reads a
byte value from the stream message. |
byte |
BytesMessage.readByte()
Reads a signed 8-bit value 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)
Reads a byte array from the bytes message stream.
|
int |
BytesMessage.readBytes(byte[] value,
int length)
Reads a portion of the bytes message stream.
|
char |
StreamMessage.readChar()
Reads a Unicode character value from the stream message.
|
char |
BytesMessage.readChar()
Reads a Unicode character value from the bytes message stream.
|
double |
StreamMessage.readDouble()
Reads a
double from the stream message. |
double |
BytesMessage.readDouble()
Reads a
double from the bytes message stream. |
float |
StreamMessage.readFloat()
Reads a
float from the stream message. |
float |
BytesMessage.readFloat()
Reads a
float from the bytes message stream. |
int |
StreamMessage.readInt()
Reads a 32-bit integer from the stream message.
|
int |
BytesMessage.readInt()
Reads a signed 32-bit integer from the bytes message stream.
|
long |
StreamMessage.readLong()
Reads a 64-bit integer from the stream message.
|
long |
BytesMessage.readLong()
Reads a signed 64-bit integer from the bytes message stream.
|
Object |
StreamMessage.readObject()
Reads an object from the stream message.
|
short |
StreamMessage.readShort()
Reads a 16-bit integer from the stream message.
|
short |
BytesMessage.readShort()
Reads a signed 16-bit number from the bytes message stream.
|
String |
StreamMessage.readString()
Reads a
String from 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 |
TopicRequestor.request(Message message)
Sends a request and waits for a reply.
|
Message |
QueueRequestor.request(Message message)
Sends a request and waits for a reply.
|
void |
StreamMessage.reset()
Puts the message body in read-only mode and repositions the stream
to the beginning.
|
void |
BytesMessage.reset()
Puts the message body in read-only mode and repositions the stream of
bytes to the beginning.
|
void |
XASession.rollback()
Throws a
TransactionInProgressException , since it should
not be called for an XASession object. |
void |
Session.rollback()
Rolls back any messages done in this transaction and releases any locks
currently held.
|
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
boolean value with the specified name into the Map. |
void |
Message.setBooleanProperty(String name,
boolean value)
Sets a
boolean property value with the specified name into
the message. |
void |
MapMessage.setByte(String name,
byte value)
Sets a
byte value with the specified name into the Map. |
void |
Message.setByteProperty(String name,
byte value)
Sets a
byte property 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 JMS 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
double value with the specified name into the Map. |
void |
Message.setDoubleProperty(String name,
double value)
Sets a
double property 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
float value with the specified name into the Map. |
void |
Message.setFloatProperty(String name,
float value)
Sets a
float property value with the specified name into
the message. |
void |
MapMessage.setInt(String name,
int value)
Sets an
int value with the specified name into the Map. |
void |
Message.setIntProperty(String name,
int value)
Sets an
int property 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
DeliveryMode value for this message. |
void |
Message.setJMSDeliveryTime(long deliveryTime)
Sets the message's delivery time value.
|
void |
Message.setJMSDestination(Destination destination)
Sets the
Destination object 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
Destination object 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
long value with the specified name into the Map. |
void |
Message.setLongProperty(String name,
long value)
Sets a
long property 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 's MessageListener . |
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
short value with the specified name into the Map. |
void |
Message.setShortProperty(String name,
short value)
Sets a
short property value with the specified name into
the message. |
void |
MapMessage.setString(String name,
String value)
Sets a
String value with the specified name into the Map. |
void |
Message.setStringProperty(String name,
String value)
Sets a
String property 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 |
ServerSession.start()
Cause the
Session 's run method to be called
to process messages that were just assigned to it. |
void |
Connection.start()
Starts (or restarts) a connection's delivery of incoming messages.
|
void |
Connection.stop()
Temporarily stops a connection's delivery of incoming messages.
|
void |
TopicSession.unsubscribe(String name)
Unsubscribes a durable subscription that has been created by a client.
|
void |
Session.unsubscribe(String name)
Unsubscribes a durable subscription that has been created by a client.
|
void |
StreamMessage.writeBoolean(boolean value)
Writes a
boolean to the stream message. |
void |
BytesMessage.writeBoolean(boolean value)
Writes a
boolean to the bytes message stream as a 1-byte
value. |
void |
StreamMessage.writeByte(byte value)
Writes a
byte to the stream message. |
void |
BytesMessage.writeByte(byte value)
Writes a
byte to the bytes message stream as a 1-byte
value. |
void |
StreamMessage.writeBytes(byte[] value)
Writes a byte array field to the stream message.
|
void |
BytesMessage.writeBytes(byte[] value)
Writes 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.writeBytes(byte[] value,
int offset,
int length)
Writes a portion of a byte array to the bytes message stream.
|
void |
StreamMessage.writeChar(char value)
Writes a
char to the stream message. |
void |
BytesMessage.writeChar(char value)
Writes a
char to the bytes message stream as a 2-byte
value, high byte first. |
void |
StreamMessage.writeDouble(double value)
Writes a
double to the stream message. |
void |
BytesMessage.writeDouble(double value)
Converts 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 |
StreamMessage.writeFloat(float value)
Writes a
float to the stream message. |
void |
BytesMessage.writeFloat(float value)
Converts 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 |
StreamMessage.writeInt(int value)
Writes an
int to the stream message. |
void |
BytesMessage.writeInt(int value)
Writes an
int to the bytes message stream as four bytes,
high byte first. |
void |
StreamMessage.writeLong(long value)
Writes a
long to the stream message. |
void |
BytesMessage.writeLong(long value)
Writes a
long to the bytes message stream as eight bytes,
high byte first. |
void |
StreamMessage.writeObject(Object value)
Writes an object to the stream message.
|
void |
BytesMessage.writeObject(Object value)
Writes an object to the bytes message stream.
|
void |
StreamMessage.writeShort(short value)
Writes a
short to the stream message. |
void |
BytesMessage.writeShort(short value)
Writes a
short to the bytes message stream as two bytes,
high byte first. |
void |
StreamMessage.writeString(String value)
Writes a
String to 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
QueueRequestor class. |
TopicRequestor(TopicSession session,
Topic topic)
Constructor for the
TopicRequestor class. |
Modifier and Type | Method and Description |
---|---|
static boolean |
JMSManagementHelper.hasOperationSucceeded(Message message)
Returns whether the invocation of the management operation on the server resource succeeded.
|
static boolean |
JMSManagementHelper.isAttributesResult(Message message)
Returns whether the JMS message corresponds to the result of a management attribute value.
|
static boolean |
JMSManagementHelper.isOperationResult(Message message)
Returns whether the JMS message corresponds to the result of a management operation invocation.
|
static void |
JMSManagementHelper.putAttribute(Message message,
String resourceName,
String attribute)
Stores a resource attribute in a JMS message to retrieve the value from the server resource.
|
static void |
JMSManagementHelper.putOperationInvocation(Message message,
String resourceName,
String operationName)
Stores an operation invocation in a JMS message to invoke the corresponding operation the value from the server resource.
|
static void |
JMSManagementHelper.putOperationInvocation(Message message,
String resourceName,
String operationName,
Object... parameters)
Stores an operation invocation in a JMS message to invoke the corresponding operation the value from the server resource.
|
Modifier and Type | Method and Description |
---|---|
static JMSException |
JMSExceptionHelper.convertFromActiveMQException(ActiveMQException me) |
static JMSException |
JMSExceptionHelper.convertFromActiveMQException(ActiveMQInterruptedException me) |
JMSException |
ActiveMQJMSClientBundle.illegalDeliveryMode(int deliveryMode) |
Modifier and Type | Method and Description |
---|---|
static JMSRuntimeException |
JmsExceptionUtils.convertToRuntimeException(JMSException e)
Converts instances of sub-classes of
JMSException into the corresponding sub-class of
JMSRuntimeException . |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQSession.ackAllConsumers() |
void |
ActiveMQMessage.acknowledge() |
void |
ActiveMQConnection.authorize() |
protected void |
ActiveMQConnection.checkClosed() |
protected void |
ActiveMQMessage.checkRead() |
protected void |
ActiveMQMessage.checkWrite() |
void |
ActiveMQTextMessage.clearBody() |
void |
ActiveMQStreamMessage.clearBody() |
void |
ActiveMQObjectMessage.clearBody() |
void |
ActiveMQMessage.clearBody() |
void |
ActiveMQMapMessage.clearBody() |
void |
ActiveMQBytesMessage.clearBody() |
void |
ActiveMQMessage.clearProperties() |
void |
ActiveMQSession.close() |
void |
ActiveMQQueueBrowser.close() |
void |
ActiveMQMessageProducer.close() |
void |
ActiveMQMessageConsumer.close() |
void |
ActiveMQConnection.close() |
void |
ActiveMQSession.commit() |
QueueBrowser |
ActiveMQSession.createBrowser(Queue queue) |
QueueBrowser |
ActiveMQSession.createBrowser(Queue queue,
String filterString) |
BytesMessage |
ActiveMQSession.createBytesMessage() |
Connection |
ActiveMQConnectionFactory.createConnection() |
Connection |
ActiveMQConnectionFactory.createConnection(String username,
String password) |
ConnectionConsumer |
ActiveMQConnection.createConnectionConsumer(Destination destination,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
ConnectionConsumer |
ActiveMQConnection.createConnectionConsumer(Queue queue,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
ConnectionConsumer |
ActiveMQConnection.createConnectionConsumer(Topic topic,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
protected ActiveMQConnection |
ActiveMQConnectionFactory.createConnectionInternal(String username,
String password,
boolean isXA,
int type) |
MessageConsumer |
ActiveMQSession.createConsumer(Destination destination) |
MessageConsumer |
ActiveMQSession.createConsumer(Destination destination,
String messageSelector) |
MessageConsumer |
ActiveMQSession.createConsumer(Destination destination,
String messageSelector,
boolean noLocal) |
ConnectionConsumer |
ActiveMQConnection.createDurableConnectionConsumer(Topic topic,
String subscriptionName,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
MessageConsumer |
ActiveMQSession.createDurableConsumer(Topic topic,
String name) |
MessageConsumer |
ActiveMQSession.createDurableConsumer(Topic topic,
String name,
String messageSelector,
boolean noLocal) |
TopicSubscriber |
ActiveMQSession.createDurableSubscriber(Topic topic,
String name) |
TopicSubscriber |
ActiveMQSession.createDurableSubscriber(Topic topic,
String name,
String messageSelector,
boolean noLocal) |
MapMessage |
ActiveMQSession.createMapMessage() |
Message |
ActiveMQSession.createMessage() |
Session |
ActiveMQConnection.createNonXAQueueSession(boolean transacted,
int acknowledgeMode)
This internal method serves basically the Resource Adapter.
|
Session |
ActiveMQConnection.createNonXASession(boolean transacted,
int acknowledgeMode)
This internal method serves basically the Resource Adapter.
|
Session |
ActiveMQConnection.createNonXATopicSession(boolean transacted,
int acknowledgeMode)
This internal method serves basically the Resource Adapter.
|
ObjectMessage |
ActiveMQSession.createObjectMessage() |
ObjectMessage |
ActiveMQSession.createObjectMessage(Serializable object) |
MessageProducer |
ActiveMQSession.createProducer(Destination destination) |
TopicPublisher |
ActiveMQSession.createPublisher(Topic topic) |
Queue |
ActiveMQSession.createQueue(String queueName) |
QueueConnection |
ActiveMQConnectionFactory.createQueueConnection() |
QueueConnection |
ActiveMQConnectionFactory.createQueueConnection(String username,
String password) |
QueueSession |
ActiveMQConnection.createQueueSession(boolean transacted,
int acknowledgeMode) |
QueueReceiver |
ActiveMQSession.createReceiver(Queue queue) |
QueueReceiver |
ActiveMQSession.createReceiver(Queue queue,
String messageSelector) |
QueueSender |
ActiveMQSession.createSender(Queue queue) |
Session |
ActiveMQConnection.createSession() |
Session |
ActiveMQConnection.createSession(boolean transacted,
int acknowledgeMode) |
Session |
ActiveMQConnection.createSession(int sessionMode) |
protected ActiveMQSession |
ActiveMQConnection.createSessionInternal(boolean isXA,
boolean transacted,
int acknowledgeMode,
int type) |
ConnectionConsumer |
ActiveMQConnection.createSharedConnectionConsumer(Topic topic,
String subscriptionName,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
MessageConsumer |
ActiveMQSession.createSharedConsumer(Topic topic,
String sharedSubscriptionName) |
MessageConsumer |
ActiveMQSession.createSharedConsumer(Topic topic,
String name,
String messageSelector)
Note: Needs to throw an exception if a subscriptionName is already in use by another topic, or if the messageSelector is different
validate multiple subscriptions on the same session.
|
ConnectionConsumer |
ActiveMQConnection.createSharedDurableConnectionConsumer(Topic topic,
String subscriptionName,
String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
MessageConsumer |
ActiveMQSession.createSharedDurableConsumer(Topic topic,
String name) |
MessageConsumer |
ActiveMQSession.createSharedDurableConsumer(Topic topic,
String name,
String messageSelector) |
StreamMessage |
ActiveMQSession.createStreamMessage() |
TopicSubscriber |
ActiveMQSession.createSubscriber(Topic topic) |
TopicSubscriber |
ActiveMQSession.createSubscriber(Topic topic,
String messageSelector,
boolean noLocal) |
TemporaryQueue |
ActiveMQSession.createTemporaryQueue() |
TemporaryTopic |
ActiveMQSession.createTemporaryTopic() |
TextMessage |
ActiveMQSession.createTextMessage() |
TextMessage |
ActiveMQSession.createTextMessage(String text) |
Topic |
ActiveMQSession.createTopic(String topicName) |
TopicConnection |
ActiveMQConnectionFactory.createTopicConnection() |
TopicConnection |
ActiveMQConnectionFactory.createTopicConnection(String username,
String password) |
TopicSession |
ActiveMQConnection.createTopicSession(boolean transacted,
int acknowledgeMode) |
XAConnection |
ActiveMQConnectionFactory.createXAConnection() |
XAConnection |
ActiveMQConnectionFactory.createXAConnection(String username,
String password) |
XAQueueConnection |
ActiveMQConnectionFactory.createXAQueueConnection() |
XAQueueConnection |
ActiveMQConnectionFactory.createXAQueueConnection(String username,
String password) |
XAQueueSession |
ActiveMQXAConnection.createXAQueueSession() |
XASession |
ActiveMQXAConnection.createXASession() |
XATopicConnection |
ActiveMQConnectionFactory.createXATopicConnection() |
XATopicConnection |
ActiveMQConnectionFactory.createXATopicConnection(String username,
String password) |
XATopicSession |
ActiveMQXAConnection.createXATopicSession() |
void |
ActiveMQDestination.delete() |
void |
ActiveMQSession.deleteTemporaryQueue(ActiveMQDestination tempQueue) |
void |
ActiveMQSession.deleteTemporaryTopic(ActiveMQDestination tempTopic) |
int |
ActiveMQSession.getAcknowledgeMode() |
<T> T |
ActiveMQMessage.getBody(Class<T> c) |
long |
ActiveMQBytesMessage.getBodyLength() |
boolean |
ActiveMQMapMessage.getBoolean(String name) |
boolean |
ActiveMQMessage.getBooleanProperty(String name) |
byte |
ActiveMQMapMessage.getByte(String name) |
byte |
ActiveMQMessage.getByteProperty(String name) |
byte[] |
ActiveMQMapMessage.getBytes(String name) |
char |
ActiveMQMapMessage.getChar(String name) |
String |
ActiveMQConnection.getClientID() |
long |
ActiveMQMessageProducer.getDeliveryDelay() |
int |
ActiveMQMessageProducer.getDeliveryMode() |
Destination |
ActiveMQMessageProducer.getDestination() |
boolean |
ActiveMQMessageProducer.getDisableMessageID() |
boolean |
ActiveMQMessageProducer.getDisableMessageTimestamp() |
double |
ActiveMQMapMessage.getDouble(String name) |
double |
ActiveMQMessage.getDoubleProperty(String name) |
Enumeration |
ActiveMQQueueBrowser.getEnumeration() |
ExceptionListener |
ActiveMQConnection.getExceptionListener() |
FailoverEventListener |
ActiveMQConnection.getFailoverListener() |
float |
ActiveMQMapMessage.getFloat(String name) |
float |
ActiveMQMessage.getFloatProperty(String name) |
int |
ActiveMQMapMessage.getInt(String name) |
int |
ActiveMQMessage.getIntProperty(String name) |
String |
ActiveMQMessage.getJMSCorrelationID() |
byte[] |
ActiveMQMessage.getJMSCorrelationIDAsBytes() |
int |
ActiveMQMessage.getJMSDeliveryMode() |
long |
ActiveMQMessage.getJMSDeliveryTime() |
Destination |
ActiveMQMessage.getJMSDestination() |
long |
ActiveMQMessage.getJMSExpiration() |
int |
ActiveMQConnectionMetaData.getJMSMajorVersion() |
int |
ActiveMQConnectionMetaData.getJMSMinorVersion() |
int |
ActiveMQMessage.getJMSPriority() |
String |
ActiveMQConnectionMetaData.getJMSProviderName() |
boolean |
ActiveMQMessage.getJMSRedelivered() |
Destination |
ActiveMQMessage.getJMSReplyTo() |
long |
ActiveMQMessage.getJMSTimestamp() |
String |
ActiveMQMessage.getJMSType() |
String |
ActiveMQConnectionMetaData.getJMSVersion() |
Enumeration |
ActiveMQConnectionMetaData.getJMSXPropertyNames() |
long |
ActiveMQMapMessage.getLong(String name) |
long |
ActiveMQMessage.getLongProperty(String name) |
Enumeration |
ActiveMQMapMessage.getMapNames() |
MessageListener |
ActiveMQSession.getMessageListener() |
MessageListener |
ActiveMQMessageConsumer.getMessageListener() |
String |
ActiveMQQueueBrowser.getMessageSelector() |
String |
ActiveMQMessageConsumer.getMessageSelector() |
ConnectionMetaData |
ActiveMQConnection.getMetaData() |
boolean |
ActiveMQMessageConsumer.getNoLocal() |
Serializable |
ActiveMQObjectMessage.getObject() |
Object |
ActiveMQMapMessage.getObject(String name) |
Object |
ActiveMQMessage.getObjectProperty(String name) |
int |
ActiveMQMessageProducer.getPriority() |
Enumeration |
ActiveMQMessage.getPropertyNames() |
int |
ActiveMQConnectionMetaData.getProviderMajorVersion() |
int |
ActiveMQConnectionMetaData.getProviderMinorVersion() |
String |
ActiveMQConnectionMetaData.getProviderVersion() |
Queue |
ActiveMQQueueBrowser.getQueue() |
Queue |
ActiveMQMessageProducer.getQueue() |
Queue |
ActiveMQMessageConsumer.getQueue() |
QueueSession |
ActiveMQSession.getQueueSession() |
Session |
ActiveMQSession.getSession() |
short |
ActiveMQMapMessage.getShort(String name) |
short |
ActiveMQMessage.getShortProperty(String name) |
String |
ActiveMQMapMessage.getString(String name) |
String |
ActiveMQMessage.getStringProperty(String name) |
long |
ActiveMQMessageProducer.getTimeToLive() |
Topic |
ActiveMQMessageProducer.getTopic() |
Topic |
ActiveMQMessageConsumer.getTopic() |
TopicSession |
ActiveMQSession.getTopicSession() |
boolean |
ActiveMQSession.getTransacted() |
boolean |
ActiveMQMapMessage.itemExists(String name) |
boolean |
ActiveMQMessage.propertyExists(String name) |
void |
ActiveMQMessageProducer.publish(Message message) |
void |
ActiveMQMessageProducer.publish(Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
ActiveMQMessageProducer.publish(Topic topic,
Message message) |
void |
ActiveMQMessageProducer.publish(Topic topic,
Message message,
int deliveryMode,
int priority,
long timeToLive) |
boolean |
ActiveMQStreamMessage.readBoolean() |
boolean |
ActiveMQBytesMessage.readBoolean() |
byte |
ActiveMQStreamMessage.readByte() |
byte |
ActiveMQBytesMessage.readByte() |
int |
ActiveMQStreamMessage.readBytes(byte[] value) |
int |
ActiveMQBytesMessage.readBytes(byte[] value) |
int |
ActiveMQBytesMessage.readBytes(byte[] value,
int length) |
char |
ActiveMQStreamMessage.readChar() |
char |
ActiveMQBytesMessage.readChar() |
double |
ActiveMQStreamMessage.readDouble() |
double |
ActiveMQBytesMessage.readDouble() |
float |
ActiveMQStreamMessage.readFloat() |
float |
ActiveMQBytesMessage.readFloat() |
int |
ActiveMQStreamMessage.readInt() |
int |
ActiveMQBytesMessage.readInt() |
long |
ActiveMQStreamMessage.readLong() |
long |
ActiveMQBytesMessage.readLong() |
Object |
ActiveMQStreamMessage.readObject() |
short |
ActiveMQStreamMessage.readShort() |
short |
ActiveMQBytesMessage.readShort() |
String |
ActiveMQStreamMessage.readString() |
int |
ActiveMQBytesMessage.readUnsignedByte() |
int |
ActiveMQBytesMessage.readUnsignedShort() |
String |
ActiveMQBytesMessage.readUTF() |
Message |
ActiveMQMessageConsumer.receive() |
Message |
ActiveMQMessageConsumer.receive(long timeout) |
Message |
ActiveMQMessageConsumer.receiveNoWait() |
void |
ActiveMQSession.recover() |
void |
ActiveMQStreamMessage.reset() |
void |
ActiveMQBytesMessage.reset() |
void |
ActiveMQSession.rollback() |
void |
ActiveMQMessage.saveToOutputStream(OutputStream output) |
void |
ActiveMQMessageProducer.send(Destination destination,
Message message) |
void |
ActiveMQMessageProducer.send(Destination destination,
Message message,
CompletionListener completionListener) |
void |
ActiveMQMessageProducer.send(Destination destination,
Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
ActiveMQMessageProducer.send(Destination destination,
Message message,
int deliveryMode,
int priority,
long timeToLive,
CompletionListener completionListener) |
void |
ActiveMQMessageProducer.send(Message message) |
void |
ActiveMQMessageProducer.send(Message message,
CompletionListener completionListener) |
void |
ActiveMQMessageProducer.send(Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
ActiveMQMessageProducer.send(Message message,
int deliveryMode,
int priority,
long timeToLive,
CompletionListener completionListener) |
void |
ActiveMQMessageProducer.send(Queue queue,
Message message) |
void |
ActiveMQMessageProducer.send(Queue queue,
Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
ActiveMQMapMessage.setBoolean(String name,
boolean value) |
void |
ActiveMQMessage.setBooleanProperty(String name,
boolean value) |
void |
ActiveMQMapMessage.setByte(String name,
byte value) |
void |
ActiveMQMessage.setByteProperty(String name,
byte value) |
void |
ActiveMQMapMessage.setBytes(String name,
byte[] value) |
void |
ActiveMQMapMessage.setBytes(String name,
byte[] value,
int offset,
int length) |
void |
ActiveMQMapMessage.setChar(String name,
char value) |
void |
ActiveMQConnection.setClientID(String clientID) |
void |
ActiveMQMessageProducer.setDeliveryDelay(long deliveryDelay) |
void |
ActiveMQMessageProducer.setDeliveryMode(int deliveryMode) |
void |
ActiveMQMessageProducer.setDisableMessageID(boolean value) |
void |
ActiveMQMessageProducer.setDisableMessageTimestamp(boolean value) |
void |
ActiveMQMapMessage.setDouble(String name,
double value) |
void |
ActiveMQMessage.setDoubleProperty(String name,
double value) |
void |
ActiveMQConnection.setExceptionListener(ExceptionListener listener) |
void |
ActiveMQConnection.setFailoverListener(FailoverEventListener listener)
Sets a FailureListener for the session which is notified if a failure occurs on the session.
|
void |
ActiveMQMapMessage.setFloat(String name,
float value) |
void |
ActiveMQMessage.setFloatProperty(String name,
float value) |
void |
ActiveMQMessage.setInputStream(InputStream input) |
void |
ActiveMQMapMessage.setInt(String name,
int value) |
void |
ActiveMQMessage.setIntProperty(String name,
int value) |
void |
ActiveMQMessage.setJMSCorrelationID(String correlationID) |
void |
ActiveMQMessage.setJMSCorrelationIDAsBytes(byte[] correlationID) |
void |
ActiveMQMessage.setJMSDeliveryMode(int deliveryMode) |
void |
ActiveMQMessage.setJMSDeliveryTime(long deliveryTime) |
void |
ActiveMQMessage.setJMSDestination(Destination destination) |
void |
ActiveMQMessage.setJMSExpiration(long expiration) |
void |
ActiveMQMessage.setJMSMessageID(String jmsMessageID) |
void |
ActiveMQMessage.setJMSPriority(int priority) |
void |
ActiveMQMessage.setJMSRedelivered(boolean redelivered) |
void |
ActiveMQMessage.setJMSReplyTo(Destination dest) |
void |
ActiveMQMessage.setJMSTimestamp(long timestamp) |
void |
ActiveMQMessage.setJMSType(String type) |
void |
ActiveMQMapMessage.setLong(String name,
long value) |
void |
ActiveMQMessage.setLongProperty(String name,
long value) |
void |
ActiveMQSession.setMessageListener(MessageListener listener) |
void |
ActiveMQMessageConsumer.setMessageListener(MessageListener listener) |
void |
ActiveMQObjectMessage.setObject(Serializable object) |
void |
ActiveMQMapMessage.setObject(String name,
Object value) |
void |
ActiveMQMessage.setObjectProperty(String name,
Object value) |
void |
ActiveMQMessage.setOutputStream(OutputStream output) |
void |
ActiveMQMessageProducer.setPriority(int defaultPriority) |
void |
ActiveMQMapMessage.setShort(String name,
short value) |
void |
ActiveMQMessage.setShortProperty(String name,
short value) |
void |
ActiveMQMapMessage.setString(String name,
String value) |
void |
ActiveMQMessage.setStringProperty(String name,
String value) |
void |
ActiveMQTextMessage.setText(String text) |
void |
ActiveMQMessageProducer.setTimeToLive(long timeToLive) |
void |
ActiveMQSession.start() |
void |
ActiveMQConnection.start() |
void |
ActiveMQSession.stop() |
void |
ActiveMQConnection.stop() |
void |
ActiveMQSession.unsubscribe(String name) |
boolean |
ActiveMQMessage.waitCompletionOnStream(long timeWait) |
void |
ActiveMQStreamMessage.writeBoolean(boolean value) |
void |
ActiveMQBytesMessage.writeBoolean(boolean value) |
void |
ActiveMQStreamMessage.writeByte(byte value) |
void |
ActiveMQBytesMessage.writeByte(byte value) |
void |
ActiveMQStreamMessage.writeBytes(byte[] value) |
void |
ActiveMQBytesMessage.writeBytes(byte[] value) |
void |
ActiveMQStreamMessage.writeBytes(byte[] value,
int offset,
int length) |
void |
ActiveMQBytesMessage.writeBytes(byte[] value,
int offset,
int length) |
void |
ActiveMQStreamMessage.writeChar(char value) |
void |
ActiveMQBytesMessage.writeChar(char value) |
void |
ActiveMQStreamMessage.writeDouble(double value) |
void |
ActiveMQBytesMessage.writeDouble(double value) |
void |
ActiveMQStreamMessage.writeFloat(float value) |
void |
ActiveMQBytesMessage.writeFloat(float value) |
void |
ActiveMQStreamMessage.writeInt(int value) |
void |
ActiveMQBytesMessage.writeInt(int value) |
void |
ActiveMQStreamMessage.writeLong(long value) |
void |
ActiveMQBytesMessage.writeLong(long value) |
void |
ActiveMQStreamMessage.writeObject(Object value) |
void |
ActiveMQBytesMessage.writeObject(Object value) |
void |
ActiveMQStreamMessage.writeShort(short value) |
void |
ActiveMQBytesMessage.writeShort(short value) |
void |
ActiveMQStreamMessage.writeString(String value) |
void |
ActiveMQBytesMessage.writeUTF(String value) |
Copyright © 2017 JBoss by Red Hat. All rights reserved.