Modifier and Type | Method and Description |
---|---|
void |
BamJmsService.init() |
Modifier and Type | Class and Description |
---|---|
class |
JmsExceptionWrapper
Wraps the actual exception with an JMS exception
|
Modifier and Type | Method and Description |
---|---|
static JMSException |
JmsExceptionWrapper.create(java.lang.Throwable rootCause)
Creates an JMSException from a throwable.
|
Modifier and Type | Method and Description |
---|---|
void |
JmsSession.acknowledge()
Acknowledge received
|
protected void |
ConnectionFactoryImpl.authenticate(java.lang.String username,
java.lang.String password) |
void |
MessageConsumerImpl.close()
Closes the consumer.
|
void |
MessageProducerImpl.close()
Closes the producer.
|
void |
QueueBrowserImpl.close() |
void |
JmsSession.close()
Closes the session
|
void |
MessageBrowserImpl.close() |
void |
ConnectionImpl.close()
Closes the connection.
|
void |
JmsSession.commit()
Commits the messages.
|
QueueBrowser |
TopicSessionImpl.createBrowser(Queue queue)
Creates a QueueBrowser to browse messages in the queue.
|
QueueBrowser |
JmsSession.createBrowser(Queue queue)
Creates a QueueBrowser to browse messages in the queue.
|
QueueBrowser |
TopicSessionImpl.createBrowser(Queue queue,
java.lang.String messageSelector)
Creates a QueueBrowser to browse messages in the queue.
|
QueueBrowser |
JmsSession.createBrowser(Queue queue,
java.lang.String messageSelector)
Creates a QueueBrowser to browse messages in the queue.
|
BytesMessage |
JmsSession.createBytesMessage()
Creates a new byte[] message.
|
Connection |
XAConnectionFactoryImpl.createConnection()
Creates a new queue connection
|
Connection |
ConnectionFactoryImpl.createConnection()
Creates a new queue connection
|
Connection |
XAConnectionFactoryImpl.createConnection(java.lang.String username,
java.lang.String password)
Creates a new connection
|
Connection |
ConnectionFactoryImpl.createConnection(java.lang.String username,
java.lang.String password)
Creates a new connection
|
ConnectionConsumer |
ConnectionImpl.createConnectionConsumer(Destination destination,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Creates a new consumer (optional)
|
ConnectionConsumer |
QueueConnectionImpl.createConnectionConsumer(Queue queue,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Creates a new consumer (optional)
|
ConnectionConsumer |
TopicConnectionImpl.createConnectionConsumer(Topic topic,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Creates a new consumer (optional)
|
MessageConsumer |
JmsSession.createConsumer(Destination destination)
Creates a consumer to receive messages.
|
MessageConsumer |
JmsSession.createConsumer(Destination destination,
java.lang.String messageSelector)
Creates a consumer to receive messages.
|
MessageConsumer |
JmsSession.createConsumer(Destination destination,
java.lang.String messageSelector,
boolean noLocal)
Creates a consumer to receive messages.
|
ConnectionConsumer |
TopicConnectionImpl.createDurableConnectionConsumer(Topic topic,
java.lang.String name,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Creates a new consumer (optional)
|
ConnectionConsumer |
ConnectionImpl.createDurableConnectionConsumer(Topic topic,
java.lang.String name,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages)
Creates a new consumer (optional)
|
TopicSubscriber |
JmsSession.createDurableSubscriber(Topic topic,
java.lang.String name)
Creates a durable subscriber to receive messages.
|
TopicSubscriber |
QueueSessionImpl.createDurableSubscriber(Topic topic,
java.lang.String name)
Creates a durable subscriber to receive messages.
|
TopicSubscriber |
JmsSession.createDurableSubscriber(Topic topic,
java.lang.String name,
java.lang.String messageSelector,
boolean noLocal)
Creates a subscriber to receive messages.
|
TopicSubscriber |
QueueSessionImpl.createDurableSubscriber(Topic topic,
java.lang.String name,
java.lang.String messageSelector,
boolean noLocal)
Creates a subscriber to receive messages.
|
MapMessage |
JmsSession.createMapMessage()
Creates a new map message.
|
Message |
JmsSession.createMessage()
Creates a message.
|
ObjectMessage |
JmsSession.createObjectMessage()
Creates an object message.
|
ObjectMessage |
JmsSession.createObjectMessage(java.io.Serializable obj)
Creates an object message.
|
MessageProducer |
JmsSession.createProducer(Destination destination)
Creates a producer to produce messages.
|
TopicPublisher |
TopicSessionImpl.createPublisher(Topic topic)
Creates a TopicSender to send messages to a topic.
|
Queue |
XAConnectionFactoryImpl.createQueue(java.lang.String name)
Creates queue.
|
Queue |
TopicSessionImpl.createQueue(java.lang.String queueName)
Creates a new queue.
|
Queue |
ConnectionFactoryImpl.createQueue(java.lang.String name)
Creates queue.
|
Queue |
JmsSession.createQueue(java.lang.String queueName)
Creates a new queue.
|
QueueConnection |
XAConnectionFactoryImpl.createQueueConnection()
Creates a new queue connection
|
QueueConnection |
ConnectionFactoryImpl.createQueueConnection()
Creates a new queue connection
|
QueueConnection |
XAConnectionFactoryImpl.createQueueConnection(java.lang.String username,
java.lang.String password)
Creates a new queue connection
|
QueueConnection |
ConnectionFactoryImpl.createQueueConnection(java.lang.String username,
java.lang.String password)
Creates a new queue connection
|
QueueSession |
QueueConnectionImpl.createQueueSession(boolean transacted,
int acknowledgeMode)
Creates a new connection session.
|
QueueReceiver |
QueueSessionImpl.createReceiver(Queue queue)
Creates a receiver to receive messages.
|
QueueReceiver |
QueueSessionImpl.createReceiver(Queue queue,
java.lang.String messageSelector)
Creates a receiver to receive messages.
|
QueueSender |
QueueSessionImpl.createSender(Queue queue)
Creates a QueueSender to send messages to a queue.
|
Session |
ConnectionImpl.createSession(boolean transacted,
int acknowledgeMode)
Creates a new connection session.
|
StreamMessage |
JmsSession.createStreamMessage()
Creates a stream message.
|
TopicSubscriber |
TopicSessionImpl.createSubscriber(Topic topic)
Creates a subscriber to receive messages.
|
TopicSubscriber |
TopicSessionImpl.createSubscriber(Topic topic,
java.lang.String messageSelector,
boolean noLocal)
Creates a subscriber to receive messages.
|
TemporaryQueue |
TopicSessionImpl.createTemporaryQueue()
Creates a temporary queue.
|
TemporaryQueue |
JmsSession.createTemporaryQueue()
Creates a temporary queue.
|
TemporaryTopic |
JmsSession.createTemporaryTopic()
Creates a temporary topic.
|
TemporaryTopic |
QueueSessionImpl.createTemporaryTopic()
Creates a temporary topic.
|
TextMessage |
JmsSession.createTextMessage()
Creates a text message.
|
TextMessage |
JmsSession.createTextMessage(java.lang.String message)
Creates a text message.
|
Topic |
XAConnectionFactoryImpl.createTopic(java.lang.String name)
Creates topics.
|
Topic |
ConnectionFactoryImpl.createTopic(java.lang.String name)
Creates topics.
|
Topic |
JmsSession.createTopic(java.lang.String topicName)
Creates a new topic.
|
Topic |
QueueSessionImpl.createTopic(java.lang.String topicName)
Creates a new topic.
|
TopicConnection |
XAConnectionFactoryImpl.createTopicConnection()
Creates a new queue connection
|
TopicConnection |
ConnectionFactoryImpl.createTopicConnection()
Creates a new queue connection
|
TopicConnection |
XAConnectionFactoryImpl.createTopicConnection(java.lang.String username,
java.lang.String password)
Creates a new queue connection
|
TopicConnection |
ConnectionFactoryImpl.createTopicConnection(java.lang.String username,
java.lang.String password)
Creates a new queue connection
|
TopicSession |
TopicConnectionImpl.createTopicSession(boolean transacted,
int acknowledgeMode)
Creates a new connection session.
|
XAConnection |
ConnectionFactoryImpl.createXAConnection() |
XAConnection |
ConnectionFactoryImpl.createXAConnection(java.lang.String username,
java.lang.String password) |
XAQueueConnection |
ConnectionFactoryImpl.createXAQueueConnection() |
XAQueueConnection |
ConnectionFactoryImpl.createXAQueueConnection(java.lang.String username,
java.lang.String password) |
XAQueueSession |
QueueConnectionImpl.createXAQueueSession()
Creates a new connection session.
|
XASession |
ConnectionImpl.createXASession()
Creates a new connection session.
|
XATopicConnection |
ConnectionFactoryImpl.createXATopicConnection() |
XATopicConnection |
ConnectionFactoryImpl.createXATopicConnection(java.lang.String username,
java.lang.String password) |
XATopicSession |
TopicConnectionImpl.createXATopicSession()
Creates a new connection session.
|
void |
TemporaryQueueImpl.delete() |
void |
TemporaryTopicImpl.delete() |
int |
JmsSession.getAcknowledgeMode()
Returns the acknowledge mode for the session.
|
java.lang.String |
JmsSession.getClientID()
Returns the connection's clientID
|
java.lang.String |
ConnectionImpl.getClientID()
Returns the connection's client identifier.
|
int |
MessageProducerImpl.getDeliveryMode()
Returns the default delivery mode.
|
protected AbstractDestination<E> |
MessageConsumerImpl.getDestination()
Returns the destination
|
Destination |
MessageProducerImpl.getDestination()
Returns the producer's destination.
|
boolean |
MessageProducerImpl.getDisableMessageID()
Returns true if message ids are disabled by default.
|
boolean |
MessageProducerImpl.getDisableMessageTimestamp()
Returns true if message timestamps are disabled by default.
|
java.util.Enumeration |
QueueBrowserImpl.getEnumeration()
Returns an enumeration of the matching messages.
|
java.util.Enumeration |
MessageBrowserImpl.getEnumeration() |
ExceptionListener |
ConnectionImpl.getExceptionListener()
Returns the connection's exception listener.
|
int |
ConnectionMetaDataImpl.getJMSMajorVersion()
Returns the major version.
|
int |
ConnectionMetaDataImpl.getJMSMinorVersion()
Returns the minor version.
|
java.lang.String |
ConnectionMetaDataImpl.getJMSProviderName()
Returns the provider name.
|
java.lang.String |
ConnectionMetaDataImpl.getJMSVersion()
Returns the version name.
|
MessageListener |
MessageConsumerImpl.getMessageListener()
Returns the message listener
|
MessageListener |
JmsSession.getMessageListener()
Returns the message listener
|
java.lang.String |
MessageConsumerImpl.getMessageSelector()
Returns the message consumer's selector.
|
java.lang.String |
QueueBrowserImpl.getMessageSelector()
Returns the message selector.
|
java.lang.String |
MessageBrowserImpl.getMessageSelector() |
java.lang.String |
TopicSubscriberImpl.getMessageSelector()
Returns the message consumer's selector.
|
ConnectionMetaData |
ConnectionImpl.getMetaData()
Returns the connection's metadata.
|
boolean |
MessageConsumerImpl.getNoLocal()
Returns true if local messages are not sent.
|
boolean |
TopicSubscriberImpl.getNoLocal()
Returns true if local messages are not sent.
|
int |
MessageProducerImpl.getPriority()
Returns the default priority
|
int |
ConnectionMetaDataImpl.getProviderMajorVersion()
Returns the provider's major version.
|
int |
ConnectionMetaDataImpl.getProviderMinorVersion()
Returns the provider's minor version.
|
java.lang.String |
ConnectionMetaDataImpl.getProviderVersion()
Returns the provider version.
|
Queue |
QueueBrowserImpl.getQueue()
Returns the browser's queue.
|
Queue |
QueueReceiverImpl.getQueue() |
Queue |
QueueSenderImpl.getQueue()
Returns the queue
|
Queue |
MessageBrowserImpl.getQueue() |
long |
MessageProducerImpl.getTimeToLive()
Returns the default time to live
|
Topic |
TopicPublisherImpl.getTopic()
Returns the topic
|
Topic |
TopicSubscriberImpl.getTopic() |
boolean |
JmsSession.getTransacted()
Returns true if the session is in a transaction.
|
boolean |
MessageConsumerImpl.isActive()
Returns true if active
|
void |
TopicPublisherImpl.publish(Message message)
Publishes a message to the topic
|
void |
TopicPublisherImpl.publish(Message message,
int deliveryMode,
int priority,
long timeToLive)
Publishes a message to the topic
|
void |
TopicPublisherImpl.publish(Topic topic,
Message message)
Publishes a message to the topic
|
void |
TopicPublisherImpl.publish(Topic topic,
Message message,
int deliveryMode,
int priority,
long timeToLive)
Publishes a message to the topic
|
Message |
MessageConsumerImpl.receive()
Receives the next message, blocking until a message is available.
|
Message |
MessageConsumerImpl.receive(long timeout)
Receives a message from the queue.
|
protected Message |
MessageConsumerImpl.receiveImpl(long timeout)
Receives a message from the queue.
|
protected Message |
TopicSubscriberImpl.receiveImpl(long timeout) |
Message |
MessageConsumerImpl.receiveNoWait()
Receives a message from the queue.
|
void |
JmsSession.recover()
Recovers the messages.
|
void |
JmsSession.rollback()
Rollsback the messages.
|
void |
JmsSession.rollbackImpl()
Rollsback the messages.
|
void |
JmsSession.send(AbstractDestination queue,
Message appMessage,
int deliveryMode,
int priority,
long timeout)
Adds a message to the session message queue.
|
void |
MessageProducerImpl.send(Destination destination,
Message message)
Sends a message to the destination
|
void |
MessageProducerImpl.send(Destination destination,
Message message,
int deliveryMode,
int priority,
long timeToLive)
Sends a message to the destination
|
void |
MessageProducerImpl.send(Message message)
Sends a message to the destination
|
void |
MessageProducerImpl.send(Message message,
int deliveryMode,
int priority,
long timeToLive)
Sends a message to the destination
|
void |
QueueSenderImpl.send(Queue queue,
Message message)
Sends a message to the queue
|
void |
QueueSenderImpl.send(Queue queue,
Message message,
int deliveryMode,
int priority,
long timeToLive)
Sends a message to the queue
|
void |
ConnectionImpl.setClientID(java.lang.String clientId)
Sets the connections client identifier.
|
void |
MessageProducerImpl.setDeliveryMode(int deliveryMode)
Sets the default delivery mode.
|
void |
MessageProducerImpl.setDisableMessageID(boolean disable)
Sets true if message ids should be disabled by default.
|
void |
MessageProducerImpl.setDisableMessageTimestamp(boolean disable)
Sets true if message timestamps should be disabled by default.
|
void |
ConnectionImpl.setExceptionListener(ExceptionListener listener)
Returns the connection's exception listener.
|
void |
MessageConsumerImpl.setMessageListener(MessageListener listener)
Sets the message listener
|
void |
JmsSession.setMessageListener(MessageListener listener)
Sets the message listener
|
void |
MessageConsumerImpl.setMessageListener(MessageListener listener,
long pollInterval)
Sets the message listener with a poll interval
|
void |
MessageProducerImpl.setPriority(int priority)
Sets the default priority.
|
void |
MessageProducerImpl.setTimeToLive(long timeToLive)
Sets the default time to live.
|
void |
ConnectionImpl.start()
Start (or restart) a connection.
|
void |
MessageConsumerImpl.stop()
Stops the consumer.
|
void |
ConnectionImpl.stop()
Stops the connection temporarily.
|
void |
JmsSession.unsubscribe(java.lang.String name)
Unsubscribe from a durable subscription.
|
void |
QueueSessionImpl.unsubscribe(java.lang.String name)
Unsubscribe from a durable subscription.
|
Constructor and Description |
---|
JmsSession(ConnectionImpl connection,
boolean isTransacted,
int ackMode,
boolean isXA) |
MessageBrowserImpl(JmsSession session,
AbstractQueue queue,
java.lang.String messageSelector) |
QueueSessionImpl(ConnectionImpl connection,
boolean isTransacted,
int ackMode,
boolean isXA)
Creates the session
|
TopicSessionImpl(ConnectionImpl conn,
boolean isTransacted,
int ackMode,
boolean isXA) |
Modifier and Type | Method and Description |
---|---|
void |
JdbcQueue.commit(int session)
Removes the first message matching the selector.
|
void |
JdbcTopic.send(Message message)
Sends the message to the queue.
|
long |
JdbcMessage.send(Message message,
int queue,
int priority,
long expireTime)
Sends the message to the queue.
|
Modifier and Type | Method and Description |
---|---|
void |
MessageImpl.acknowledge()
Acknowledge receipt of this message.
|
protected void |
MessageImpl.checkBodyReadable() |
protected void |
MessageImpl.checkBodyWriteable() |
protected void |
MessageImpl.checkHeaderWriteable() |
protected void |
MessageImpl.checkPropertyWriteable() |
void |
BytesMessageImpl.clearBody()
Clears the message and puts it into write mode.
|
void |
TextMessageImpl.clearBody()
Clears the body.
|
void |
ObjectMessageImpl.clearBody()
Clears the body
|
void |
StreamMessageImpl.clearBody()
Clears the message and puts it into write mode.
|
void |
MapMessageImpl.clearBody()
Clears the message and puts it into write mode.
|
void |
MessageImpl.clearBody()
Clears the body, setting write mode.
|
void |
MessageImpl.clearProperties()
Clears the message properties, making them writeable.
|
MessageImpl |
MessageFactory.copy(Message msg)
Copy the message.
|
TextMessage |
MessageFactory.createTextMessage(java.lang.String msg)
Creates a new JMS text message.
|
long |
BytesMessageImpl.getBodyLength() |
boolean |
MapMessageImpl.getBoolean(java.lang.String name)
Get a boolean from the stream.
|
boolean |
MessageImpl.getBooleanProperty(java.lang.String name)
Returns a boolean property with the given name.
|
byte |
MapMessageImpl.getByte(java.lang.String name)
Get a byte from the stream.
|
byte |
MessageImpl.getByteProperty(java.lang.String name)
Returns a property as a byte
|
byte[] |
MapMessageImpl.getBytes(java.lang.String name)
Get a byte array object from the stream.
|
int |
MapMessageImpl.getBytes(java.lang.String name,
byte[] value)
Get a byte array object from the stream.
|
char |
MapMessageImpl.getChar(java.lang.String name)
Get a character object from the stream.
|
double |
MapMessageImpl.getDouble(java.lang.String name)
Get a double from the stream.
|
double |
MessageImpl.getDoubleProperty(java.lang.String name)
Returns a property as a double
|
float |
MapMessageImpl.getFloat(java.lang.String name)
Get a float from the stream.
|
float |
MessageImpl.getFloatProperty(java.lang.String name)
Returns a property as a float
|
int |
MapMessageImpl.getInt(java.lang.String name)
Get an integer from the stream.
|
int |
MessageImpl.getIntProperty(java.lang.String name)
Returns a property as an integer
|
java.lang.String |
MessageImpl.getJMSCorrelationID()
Returns the correlation id.
|
byte[] |
MessageImpl.getJMSCorrelationIDAsBytes()
Returns the correlation id.
|
int |
MessageImpl.getJMSDeliveryMode()
Gets the delivery model
|
Destination |
MessageImpl.getJMSDestination()
Gets the destination
|
long |
MessageImpl.getJMSExpiration()
Returns the message expiration time.
|
Destination |
MessageImpl.getJMSReplyTo()
Gets the reply-to destination
|
long |
MessageImpl.getJMSTimestamp()
Returns the time the message was sent.
|
java.lang.String |
MessageImpl.getJMSType()
Returns the message type
|
long |
MapMessageImpl.getLong(java.lang.String name)
Get a long from the stream.
|
long |
MessageImpl.getLongProperty(java.lang.String name)
Returns a property as a long
|
java.util.Enumeration |
MapMessageImpl.getMapNames()
Returns an enumeration of the map names.
|
java.io.Serializable |
ObjectMessageImpl.getObject()
Reads the object from the stream.
|
java.lang.Object |
MapMessageImpl.getObject(java.lang.String name)
Gets the next object.
|
java.lang.Object |
MessageImpl.getObjectProperty(java.lang.String name)
Returns a string property.
|
java.util.Enumeration |
MessageImpl.getPropertyNames()
Returns an enumeration of the message's properties.
|
protected ReadStream |
BytesMessageImpl.getReadStream() |
short |
MapMessageImpl.getShort(java.lang.String name)
Get a short from the stream.
|
short |
MessageImpl.getShortProperty(java.lang.String name)
Returns a property as a short
|
java.lang.String |
MapMessageImpl.getString(java.lang.String name)
Get a string from the stream.
|
java.lang.String |
MessageImpl.getStringProperty(java.lang.String name)
Returns a string property.
|
java.lang.String |
TextMessageImpl.getText()
Returns the message text.
|
protected WriteStream |
BytesMessageImpl.getWriteStream() |
boolean |
MapMessageImpl.itemExists(java.lang.String name)
Returns true if the object exists.
|
boolean |
MessageImpl.propertyExists(java.lang.String name)
Returns true if the property exists.
|
void |
BytesMessageImpl.readBody(java.io.InputStream is)
Read the body from an input stream.
|
void |
TextMessageImpl.readBody(java.io.InputStream is)
Read the body from an input stream.
|
void |
ObjectMessageImpl.readBody(java.io.InputStream is)
Read the body from an input stream.
|
void |
StreamMessageImpl.readBody(java.io.InputStream is)
Read the body from an input stream.
|
void |
MapMessageImpl.readBody(java.io.InputStream is)
Read the body from an input stream.
|
void |
MessageImpl.readBody(java.io.InputStream is)
Read the body from an input stream.
|
boolean |
BytesMessageImpl.readBoolean()
Read a boolean from the stream.
|
boolean |
StreamMessageImpl.readBoolean()
Read a boolean from the stream.
|
byte |
BytesMessageImpl.readByte()
Read a byte from the stream.
|
byte |
StreamMessageImpl.readByte()
Read a byte from the stream.
|
int |
BytesMessageImpl.readBytes(byte[] value)
Read a byte array object from the stream.
|
int |
StreamMessageImpl.readBytes(byte[] value)
Read a byte array object from the stream.
|
int |
BytesMessageImpl.readBytes(byte[] value,
int length)
Read a byte array object from the stream.
|
char |
BytesMessageImpl.readChar()
Read a character object from the stream.
|
char |
StreamMessageImpl.readChar()
Read a character object from the stream.
|
double |
BytesMessageImpl.readDouble()
Read a double from the stream.
|
double |
StreamMessageImpl.readDouble()
Read a double from the stream.
|
float |
BytesMessageImpl.readFloat()
Read a float from the stream.
|
float |
StreamMessageImpl.readFloat()
Read a float from the stream.
|
int |
BytesMessageImpl.readInt()
Read an integer from the stream.
|
int |
StreamMessageImpl.readInt()
Read an integer from the stream.
|
long |
BytesMessageImpl.readLong()
Read a long from the stream.
|
long |
StreamMessageImpl.readLong()
Read a long from the stream.
|
java.lang.Object |
StreamMessageImpl.readObject()
Reads the next object.
|
void |
MessageImpl.readProperties(java.io.InputStream is)
Read the properties from an input stream.
|
short |
BytesMessageImpl.readShort()
Read a short from the stream.
|
short |
StreamMessageImpl.readShort()
Read a short from the stream.
|
java.lang.String |
StreamMessageImpl.readString()
Read a string from the stream.
|
int |
BytesMessageImpl.readUnsignedByte()
Read an unsigned byte from the stream.
|
int |
BytesMessageImpl.readUnsignedShort()
Read an unsigned short from the stream.
|
java.lang.String |
BytesMessageImpl.readUTF()
Read a string from the stream.
|
void |
BytesMessageImpl.reset()
Set the stream for reading.
|
void |
StreamMessageImpl.reset()
Set the stream for reading.
|
void |
MapMessageImpl.setBoolean(java.lang.String name,
boolean b)
Sets a boolean to the stream.
|
void |
MessageImpl.setBooleanProperty(java.lang.String name,
boolean value)
Sets a boolean property.
|
void |
MapMessageImpl.setByte(java.lang.String name,
byte b)
Sets a byte to the stream.
|
void |
MessageImpl.setByteProperty(java.lang.String name,
byte value)
Sets a byte property.
|
void |
MapMessageImpl.setBytes(java.lang.String name,
byte[] buf)
Sets a byte array to the stream.
|
void |
MapMessageImpl.setBytes(java.lang.String name,
byte[] buf,
int offset,
int length)
Sets a byte array to the stream.
|
void |
MapMessageImpl.setChar(java.lang.String name,
char ch)
Sets a character to the stream.
|
void |
MapMessageImpl.setDouble(java.lang.String name,
double d)
Sets a double to the stream.
|
void |
MessageImpl.setDoubleProperty(java.lang.String name,
double value)
Sets a double property.
|
void |
MapMessageImpl.setFloat(java.lang.String name,
float f)
Sets a float to the stream.
|
void |
MessageImpl.setFloatProperty(java.lang.String name,
float value)
Sets a float property.
|
void |
MapMessageImpl.setInt(java.lang.String name,
int i)
Sets an integer to the stream.
|
void |
MessageImpl.setIntProperty(java.lang.String name,
int value)
Sets an integer property.
|
void |
MessageImpl.setJMSCorrelationID(java.lang.String id)
Sets the correlation id.
|
void |
MessageImpl.setJMSCorrelationIDAsBytes(byte[] id)
Sets the correlation id.
|
void |
MessageImpl.setJMSDeliveryMode(int deliveryMode)
Sets the delivery mode
|
void |
MessageImpl.setJMSDestination(Destination destination)
Sets the reply-to destination
|
void |
MessageImpl.setJMSExpiration(long time)
Sets the message expiration type.
|
void |
MessageImpl.setJMSReplyTo(Destination replyTo)
Sets the reply-to destination
|
void |
MessageImpl.setJMSTimestamp(long time)
Sets the time the message was sent.
|
void |
MessageImpl.setJMSType(java.lang.String type)
Sets the message type.
|
void |
MapMessageImpl.setLong(java.lang.String name,
long l)
Sets a long to the stream.
|
void |
MessageImpl.setLongProperty(java.lang.String name,
long value)
Sets a long property.
|
void |
ObjectMessageImpl.setObject(java.io.Serializable o)
Writes the object to the stream.
|
void |
MapMessageImpl.setObject(java.lang.String name,
java.lang.Object obj)
Sets the next object.
|
void |
MessageImpl.setObjectProperty(java.lang.String name,
java.lang.Object value)
Sets an object property.
|
void |
BytesMessageImpl.setReceive()
Sets the body for reading.
|
void |
StreamMessageImpl.setReceive()
Sets the body for reading.
|
void |
MessageImpl.setReceive()
Sets the body for reading.
|
void |
MapMessageImpl.setShort(java.lang.String name,
short s)
Sets a short to the stream.
|
void |
MessageImpl.setShortProperty(java.lang.String name,
short value)
Sets a short property.
|
void |
MapMessageImpl.setString(java.lang.String name,
java.lang.String s)
Sets a string to the stream.
|
void |
MessageImpl.setStringProperty(java.lang.String name,
java.lang.String value)
Sets a string property.
|
void |
TextMessageImpl.setText(java.lang.String text)
Returns the message text.
|
static boolean |
ObjectConverter.toBoolean(java.lang.Object obj)
Returns an object converted to a boolean.
|
static byte |
ObjectConverter.toByte(java.lang.Object obj)
Returns a property as a byte
|
static byte[] |
ObjectConverter.toBytes(java.lang.Object obj)
Returns a property as a byte[]
|
static char |
ObjectConverter.toChar(java.lang.Object obj)
Returns a property as a char
|
static double |
ObjectConverter.toDouble(java.lang.Object obj)
Returns a property as a double
|
static float |
ObjectConverter.toFloat(java.lang.Object obj)
Returns a property as a float
|
static int |
ObjectConverter.toInt(java.lang.Object obj)
Returns a property as an integer
|
static long |
ObjectConverter.toLong(java.lang.Object obj)
Returns a property as a long
|
static short |
ObjectConverter.toShort(java.lang.Object obj)
Returns a property as a short
|
static java.lang.String |
ObjectConverter.toString(java.lang.Object obj)
Returns a property as a string
|
void |
BytesMessageImpl.writeBoolean(boolean b)
Writes a boolean to the stream.
|
void |
StreamMessageImpl.writeBoolean(boolean b)
Writes a boolean to the stream.
|
void |
BytesMessageImpl.writeByte(byte b)
Writes a byte to the stream.
|
void |
StreamMessageImpl.writeByte(byte b)
Writes a byte to the stream.
|
void |
BytesMessageImpl.writeBytes(byte[] buf)
Writes a byte array to the stream.
|
void |
StreamMessageImpl.writeBytes(byte[] buf)
Writes a byte array to the stream.
|
void |
BytesMessageImpl.writeBytes(byte[] buf,
int offset,
int length)
Writes a byte array to the stream.
|
void |
StreamMessageImpl.writeBytes(byte[] buf,
int offset,
int length)
Writes a byte array to the stream.
|
void |
BytesMessageImpl.writeChar(char ch)
Writes a character to the stream.
|
void |
StreamMessageImpl.writeChar(char ch)
Writes a character to the stream.
|
void |
BytesMessageImpl.writeDouble(double d)
Writes a double to the stream.
|
void |
StreamMessageImpl.writeDouble(double d)
Writes a double to the stream.
|
void |
BytesMessageImpl.writeFloat(float f)
Writes a float to the stream.
|
void |
StreamMessageImpl.writeFloat(float f)
Writes a float to the stream.
|
void |
BytesMessageImpl.writeInt(int i)
Writes an integer to the stream.
|
void |
StreamMessageImpl.writeInt(int i)
Writes an integer to the stream.
|
void |
BytesMessageImpl.writeLong(long l)
Writes a long to the stream.
|
void |
StreamMessageImpl.writeLong(long l)
Writes a long to the stream.
|
void |
BytesMessageImpl.writeObject(java.lang.Object obj)
Writes the next object.
|
void |
StreamMessageImpl.writeObject(java.lang.Object obj)
Writes the next object.
|
void |
BytesMessageImpl.writeShort(short s)
Writes a short to the stream.
|
void |
StreamMessageImpl.writeShort(short s)
Writes a short to the stream.
|
void |
StreamMessageImpl.writeString(java.lang.String s)
Writes a string to the stream.
|
void |
BytesMessageImpl.writeUTF(java.lang.String s)
Writes a string to the stream.
|
Constructor and Description |
---|
MessageImpl(Message msg)
Create a message, copying the properties
|
ObjectMessageImpl(ObjectMessage msg) |
ObjectMessageImpl(java.io.Serializable value) |
TextMessageImpl(TextMessage msg) |
Modifier and Type | Method and Description |
---|---|
protected MessageConsumer |
JmsBlockingQueue.getReadConsumer() |
protected MessageProducer |
JmsBlockingQueue.getWriteProducer() |
Modifier and Type | Method and Description |
---|---|
void |
MessageSenderResource.init()
Initialize the sender resource.
|
void |
ListenerResource.init() |
void |
ListenerResource.stop() |
Modifier and Type | Method and Description |
---|---|
JMSException |
SelectorParser.error(java.lang.String msg)
Creates an error.
|
Modifier and Type | Method and Description |
---|---|
java.lang.Object |
OrSelector.evaluate(Message message)
Evaluate the message.
|
java.lang.Object |
LikeSelector.evaluate(Message message)
Evaluate the message.
|
java.lang.Object |
BooleanBinarySelector.evaluate(Message message)
Evaluate the message.
|
boolean |
Selector.isMatch(Message message) |
Selector |
SelectorParser.parse(java.lang.String query) |
protected double |
Selector.toDouble(java.lang.Object obj) |
protected long |
Selector.toLong(java.lang.Object obj) |
Modifier and Type | Method and Description |
---|---|
void |
HessianListener.stop() |
Modifier and Type | Class and Description |
---|---|
class |
JMSExceptionWrapper
Wraps the actual exception with an JMS exception
|
Modifier and Type | Method and Description |
---|---|
static JMSException |
JMSExceptionWrapper.create(java.lang.Throwable rootCause)
Creates an JMSException from a throwable.
|
Modifier and Type | Method and Description |
---|---|
Value |
JMSQueue.receive(Env env,
long timeout) |
boolean |
JMSQueue.send(Value value,
JMSQueue replyTo) |
Modifier and Type | Class and Description |
---|---|
class |
IllegalStateException
The exception
|
class |
InvalidClientIDException
The exception
|
class |
InvalidDestinationException
The exception
|
class |
InvalidSelectorException
The exception
|
class |
JMSSecurityException
The exception
|
class |
MessageEOFException
The exception
|
class |
MessageFormatException
The exception
|
class |
MessageNotReadableException
The exception
|
class |
MessageNotWriteableException
The exception
|
class |
ResourceAllocationException
The exception
|
class |
TransactionInProgressException
The exception
|
class |
TransactionRolledBackException
The exception
|
Modifier and Type | Method and Description |
---|---|
void |
ExceptionListener.onException(JMSException e) |
Modifier and Type | Method and Description |
---|---|
void |
Message.acknowledge() |
void |
Message.clearBody() |
void |
Message.clearProperties() |
void |
TopicRequestor.close() |
void |
Connection.close() |
void |
ConnectionConsumer.close() |
void |
QueueRequestor.close() |
void |
MessageProducer.close() |
void |
QueueBrowser.close() |
void |
MessageConsumer.close() |
void |
Session.close() |
void |
XASession.commit() |
void |
Session.commit() |
QueueBrowser |
QueueSession.createBrowser(Queue queue) |
QueueBrowser |
Session.createBrowser(Queue queue) |
QueueBrowser |
QueueSession.createBrowser(Queue queue,
java.lang.String messageSelector) |
QueueBrowser |
Session.createBrowser(Queue queue,
java.lang.String messageSelector) |
BytesMessage |
Session.createBytesMessage() |
Connection |
ConnectionFactory.createConnection() |
Connection |
ConnectionFactory.createConnection(java.lang.String userName,
java.lang.String password) |
ConnectionConsumer |
Connection.createConnectionConsumer(Destination destination,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
ConnectionConsumer |
QueueConnection.createConnectionConsumer(Queue queue,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
ConnectionConsumer |
TopicConnection.createConnectionConsumer(Topic topic,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
MessageConsumer |
Session.createConsumer(Destination destination) |
MessageConsumer |
Session.createConsumer(Destination destination,
java.lang.String selector) |
MessageConsumer |
Session.createConsumer(Destination destination,
java.lang.String selector,
boolean noLocal) |
ConnectionConsumer |
Connection.createDurableConnectionConsumer(Topic topic,
java.lang.String subscriptionName,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
ConnectionConsumer |
TopicConnection.createDurableConnectionConsumer(Topic topic,
java.lang.String subscriptionName,
java.lang.String messageSelector,
ServerSessionPool sessionPool,
int maxMessages) |
TopicSubscriber |
TopicSession.createDurableSubscriber(Topic topic,
java.lang.String name) |
TopicSubscriber |
Session.createDurableSubscriber(Topic topic,
java.lang.String queue) |
TopicSubscriber |
TopicSession.createDurableSubscriber(Topic topic,
java.lang.String name,
java.lang.String messageSelector,
boolean noLocal) |
TopicSubscriber |
Session.createDurableSubscriber(Topic topic,
java.lang.String queue,
java.lang.String messageSelector,
boolean noLocal) |
MapMessage |
Session.createMapMessage() |
Message |
Session.createMessage() |
ObjectMessage |
Session.createObjectMessage() |
ObjectMessage |
Session.createObjectMessage(java.io.Serializable object) |
MessageProducer |
Session.createProducer(Destination destination) |
TopicPublisher |
TopicSession.createPublisher(Topic topic) |
Queue |
QueueSession.createQueue(java.lang.String queueName) |
Queue |
Session.createQueue(java.lang.String queueName) |
QueueConnection |
QueueConnectionFactory.createQueueConnection() |
QueueConnection |
QueueConnectionFactory.createQueueConnection(java.lang.String userName,
java.lang.String password) |
QueueSession |
QueueConnection.createQueueSession(boolean transacted,
int acknowledgeMode) |
QueueSession |
XAQueueConnection.createQueueSession(boolean transacted,
int acknowledgeMode) |
QueueReceiver |
QueueSession.createReceiver(Queue queue) |
QueueReceiver |
QueueSession.createReceiver(Queue queue,
java.lang.String messageSelector) |
QueueSender |
QueueSession.createSender(Queue queue) |
Session |
Connection.createSession(boolean transacted,
int acknowledgeMode) |
Session |
XAConnection.createSession(boolean transacted,
int acknowledgeMode) |
StreamMessage |
Session.createStreamMessage() |
TopicSubscriber |
TopicSession.createSubscriber(Topic topic) |
TopicSubscriber |
TopicSession.createSubscriber(Topic topic,
java.lang.String messageSelector,
boolean noLocal) |
TemporaryQueue |
QueueSession.createTemporaryQueue() |
TemporaryQueue |
Session.createTemporaryQueue() |
TemporaryTopic |
TopicSession.createTemporaryTopic() |
TemporaryTopic |
Session.createTemporaryTopic() |
TextMessage |
Session.createTextMessage() |
TextMessage |
Session.createTextMessage(java.lang.String text) |
Topic |
TopicSession.createTopic(java.lang.String topicName) |
Topic |
Session.createTopic(java.lang.String queueName) |
TopicConnection |
TopicConnectionFactory.createTopicConnection() |
TopicConnection |
TopicConnectionFactory.createTopicConnection(java.lang.String userName,
java.lang.String password) |
TopicSession |
XATopicConnection.createTopicSession(boolean transacted,
int acknowledgeMode) |
TopicSession |
TopicConnection.createTopicSession(boolean transacted,
int acknowledgeMode) |
XAConnection |
XAConnectionFactory.createXAConnection() |
XAConnection |
XAConnectionFactory.createXAConnection(java.lang.String userName,
java.lang.String password) |
XAQueueConnection |
XAQueueConnectionFactory.createXAQueueConnection() |
XAQueueConnection |
XAQueueConnectionFactory.createXAQueueConnection(java.lang.String userName,
java.lang.String password) |
XAQueueSession |
XAQueueConnection.createXAQueueSession() |
XASession |
XAConnection.createXASession() |
XATopicConnection |
XATopicConnectionFactory.createXATopicConnection() |
XATopicConnection |
XATopicConnectionFactory.createXATopicConnection(java.lang.String userName,
java.lang.String password) |
XATopicSession |
XATopicConnection.createXATopicSession() |
void |
TemporaryTopic.delete() |
void |
TemporaryQueue.delete() |
int |
Session.getAcknowledgeMode() |
long |
BytesMessage.getBodyLength() |
boolean |
MapMessage.getBoolean(java.lang.String name) |
boolean |
Message.getBooleanProperty(java.lang.String name) |
byte |
MapMessage.getByte(java.lang.String name) |
byte |
Message.getByteProperty(java.lang.String name) |
byte[] |
MapMessage.getBytes(java.lang.String name) |
char |
MapMessage.getChar(java.lang.String name) |
java.lang.String |
Connection.getClientID() |
int |
MessageProducer.getDeliveryMode() |
Destination |
MessageProducer.getDestination() |
boolean |
MessageProducer.getDisableMessageID() |
boolean |
MessageProducer.getDisableMessageTimestamp() |
double |
MapMessage.getDouble(java.lang.String name) |
double |
Message.getDoubleProperty(java.lang.String name) |
java.util.Enumeration |
QueueBrowser.getEnumeration() |
ExceptionListener |
Connection.getExceptionListener() |
float |
MapMessage.getFloat(java.lang.String name) |
float |
Message.getFloatProperty(java.lang.String name) |
int |
MapMessage.getInt(java.lang.String name) |
int |
Message.getIntProperty(java.lang.String name) |
java.lang.String |
Message.getJMSCorrelationID() |
byte[] |
Message.getJMSCorrelationIDAsBytes() |
int |
Message.getJMSDeliveryMode() |
Destination |
Message.getJMSDestination() |
long |
Message.getJMSExpiration() |
int |
ConnectionMetaData.getJMSMajorVersion() |
java.lang.String |
Message.getJMSMessageID() |
int |
ConnectionMetaData.getJMSMinorVersion() |
int |
Message.getJMSPriority() |
java.lang.String |
ConnectionMetaData.getJMSProviderName() |
boolean |
Message.getJMSRedelivered() |
Destination |
Message.getJMSReplyTo() |
long |
Message.getJMSTimestamp() |
java.lang.String |
Message.getJMSType() |
java.lang.String |
ConnectionMetaData.getJMSVersion() |
java.util.Enumeration |
ConnectionMetaData.getJMSXPropertyNames() |
long |
MapMessage.getLong(java.lang.String name) |
long |
Message.getLongProperty(java.lang.String name) |
java.util.Enumeration |
MapMessage.getMapNames() |
MessageListener |
MessageConsumer.getMessageListener() |
MessageListener |
Session.getMessageListener() |
java.lang.String |
QueueBrowser.getMessageSelector() |
java.lang.String |
MessageConsumer.getMessageSelector() |
ConnectionMetaData |
Connection.getMetaData() |
boolean |
TopicSubscriber.getNoLocal() |
java.io.Serializable |
ObjectMessage.getObject() |
java.lang.Object |
MapMessage.getObject(java.lang.String name) |
java.lang.Object |
Message.getObjectProperty(java.lang.String name) |
int |
MessageProducer.getPriority() |
java.util.Enumeration |
Message.getPropertyNames() |
int |
ConnectionMetaData.getProviderMajorVersion() |
int |
ConnectionMetaData.getProviderMinorVersion() |
java.lang.String |
ConnectionMetaData.getProviderVersion() |
Queue |
QueueSender.getQueue() |
Queue |
QueueReceiver.getQueue() |
Queue |
QueueBrowser.getQueue() |
java.lang.String |
Queue.getQueueName() |
QueueSession |
XAQueueSession.getQueueSession() |
ServerSession |
ServerSessionPool.getServerSession() |
ServerSessionPool |
ConnectionConsumer.getServerSessionPool() |
Session |
XASession.getSession() |
Session |
ServerSession.getSession() |
short |
MapMessage.getShort(java.lang.String name) |
short |
Message.getShortProperty(java.lang.String name) |
java.lang.String |
MapMessage.getString(java.lang.String name) |
java.lang.String |
Message.getStringProperty(java.lang.String name) |
java.lang.String |
TextMessage.getText() |
long |
MessageProducer.getTimeToLive() |
Topic |
TopicPublisher.getTopic() |
Topic |
TopicSubscriber.getTopic() |
java.lang.String |
Topic.getTopicName() |
TopicSession |
XATopicSession.getTopicSession() |
boolean |
XASession.getTransacted() |
boolean |
Session.getTransacted() |
boolean |
MapMessage.itemExists(java.lang.String name) |
boolean |
Message.propertyExists(java.lang.String name) |
void |
TopicPublisher.publish(Message message) |
void |
TopicPublisher.publish(Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
TopicPublisher.publish(Topic topic,
Message message) |
void |
TopicPublisher.publish(Topic topic,
Message message,
int deliveryMode,
int priority,
long timeToLive) |
boolean |
BytesMessage.readBoolean() |
boolean |
StreamMessage.readBoolean() |
byte |
BytesMessage.readByte() |
byte |
StreamMessage.readByte() |
int |
BytesMessage.readBytes(byte[] value) |
int |
StreamMessage.readBytes(byte[] value) |
int |
BytesMessage.readBytes(byte[] value,
int length) |
char |
BytesMessage.readChar() |
char |
StreamMessage.readChar() |
double |
BytesMessage.readDouble() |
double |
StreamMessage.readDouble() |
float |
BytesMessage.readFloat() |
float |
StreamMessage.readFloat() |
int |
BytesMessage.readInt() |
int |
StreamMessage.readInt() |
long |
BytesMessage.readLong() |
long |
StreamMessage.readLong() |
java.lang.Object |
StreamMessage.readObject() |
short |
BytesMessage.readShort() |
short |
StreamMessage.readShort() |
java.lang.String |
StreamMessage.readString() |
int |
BytesMessage.readUnsignedByte() |
int |
BytesMessage.readUnsignedShort() |
java.lang.String |
BytesMessage.readUTF() |
Message |
MessageConsumer.receive() |
Message |
MessageConsumer.receive(long timeout) |
Message |
MessageConsumer.receiveNoWait() |
void |
Session.recover() |
Message |
TopicRequestor.request(Message message) |
Message |
QueueRequestor.request(Message message) |
void |
BytesMessage.reset() |
void |
StreamMessage.reset() |
void |
XASession.rollback() |
void |
Session.rollback() |
void |
MessageProducer.send(Destination destination,
Message message) |
void |
MessageProducer.send(Destination destination,
Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
QueueSender.send(Message message) |
void |
MessageProducer.send(Message message) |
void |
QueueSender.send(Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
MessageProducer.send(Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
QueueSender.send(Queue queue,
Message message) |
void |
QueueSender.send(Queue queue,
Message message,
int deliveryMode,
int priority,
long timeToLive) |
void |
MapMessage.setBoolean(java.lang.String name,
boolean value) |
void |
Message.setBooleanProperty(java.lang.String name,
boolean value) |
void |
MapMessage.setByte(java.lang.String name,
byte value) |
void |
Message.setByteProperty(java.lang.String name,
byte value) |
void |
MapMessage.setBytes(java.lang.String name,
byte[] value) |
void |
MapMessage.setBytes(java.lang.String name,
byte[] value,
int offset,
int length) |
void |
MapMessage.setChar(java.lang.String name,
char value) |
void |
Connection.setClientID(java.lang.String clientID) |
void |
MessageProducer.setDeliveryMode(int deliveryMode) |
void |
MessageProducer.setDisableMessageID(boolean value) |
void |
MessageProducer.setDisableMessageTimestamp(boolean value) |
void |
MapMessage.setDouble(java.lang.String name,
double value) |
void |
Message.setDoubleProperty(java.lang.String name,
double value) |
void |
Connection.setExceptionListener(ExceptionListener listener) |
void |
MapMessage.setFloat(java.lang.String name,
float value) |
void |
Message.setFloatProperty(java.lang.String name,
float value) |
void |
MapMessage.setInt(java.lang.String name,
int value) |
void |
Message.setIntProperty(java.lang.String name,
int value) |
void |
Message.setJMSCorrelationID(java.lang.String id) |
void |
Message.setJMSCorrelationIDAsBytes(byte[] value) |
void |
Message.setJMSDeliveryMode(int deliveryMode) |
void |
Message.setJMSDestination(Destination replyTo) |
void |
Message.setJMSExpiration(long expiration) |
void |
Message.setJMSMessageID(java.lang.String id) |
void |
Message.setJMSPriority(int expiration) |
void |
Message.setJMSRedelivered(boolean isRedelivered) |
void |
Message.setJMSReplyTo(Destination replyTo) |
void |
Message.setJMSTimestamp(long timestamp) |
void |
Message.setJMSType(java.lang.String type) |
void |
MapMessage.setLong(java.lang.String name,
long value) |
void |
Message.setLongProperty(java.lang.String name,
long value) |
void |
MessageConsumer.setMessageListener(MessageListener listener) |
void |
Session.setMessageListener(MessageListener listener) |
void |
ObjectMessage.setObject(java.io.Serializable object) |
void |
MapMessage.setObject(java.lang.String name,
java.lang.Object value) |
void |
Message.setObjectProperty(java.lang.String name,
java.lang.Object value) |
void |
MessageProducer.setPriority(int defaultPriority) |
void |
MapMessage.setShort(java.lang.String name,
short value) |
void |
Message.setShortProperty(java.lang.String name,
short value) |
void |
MapMessage.setString(java.lang.String name,
java.lang.String value) |
void |
Message.setStringProperty(java.lang.String name,
java.lang.String value) |
void |
TextMessage.setText(java.lang.String text) |
void |
MessageProducer.setTimeToLive(long timeToLive) |
void |
Connection.start() |
void |
ServerSession.start() |
void |
Connection.stop() |
void |
TopicSession.unsubscribe(java.lang.String name) |
void |
Session.unsubscribe(java.lang.String name) |
void |
BytesMessage.writeBoolean(boolean value) |
void |
StreamMessage.writeBoolean(boolean value) |
void |
BytesMessage.writeByte(byte value) |
void |
StreamMessage.writeByte(byte value) |
void |
BytesMessage.writeBytes(byte[] value) |
void |
StreamMessage.writeBytes(byte[] value) |
void |
BytesMessage.writeBytes(byte[] value,
int offset,
int length) |
void |
StreamMessage.writeBytes(byte[] value,
int offset,
int length) |
void |
BytesMessage.writeChar(char value) |
void |
StreamMessage.writeChar(char value) |
void |
BytesMessage.writeDouble(double value) |
void |
StreamMessage.writeDouble(double value) |
void |
BytesMessage.writeFloat(float value) |
void |
StreamMessage.writeFloat(float value) |
void |
BytesMessage.writeInt(int value) |
void |
StreamMessage.writeInt(int value) |
void |
BytesMessage.writeLong(long value) |
void |
StreamMessage.writeLong(long value) |
void |
BytesMessage.writeObject(java.lang.Object value) |
void |
StreamMessage.writeObject(java.lang.Object value) |
void |
BytesMessage.writeShort(short value) |
void |
StreamMessage.writeShort(short value) |
void |
StreamMessage.writeString(java.lang.String value) |
void |
BytesMessage.writeUTF(java.lang.String value) |
Constructor and Description |
---|
QueueRequestor(QueueSession session,
Queue queue) |
TopicRequestor(TopicSession session,
Topic topic) |