diff --git a/Makefile b/Makefile index aa0bfc77..b4f2276b 100644 --- a/Makefile +++ b/Makefile @@ -9,6 +9,8 @@ DEPS_DIR = deps endif endif +export PATH := $(CURDIR):$(CURDIR)/scripts:$(PATH) + MVN_FLAGS += -Ddeps.dir="$(abspath $(DEPS_DIR))" .PHONY: all deps tests clean distclean @@ -33,3 +35,7 @@ distclean: clean $(MAKE) -C $(DEPS_DIR)/rabbitmq_codegen clean .PHONY: cluster-other-node + +.PHONY: doc +doc: ## Generate PerfTest documentation + @mvnw asciidoctor:process-asciidoc diff --git a/jms-client-compliance.md b/jms-client-compliance.md new file mode 100644 index 00000000..73a3b1fb --- /dev/null +++ b/jms-client-compliance.md @@ -0,0 +1,1587 @@ + + +# JMS Client Reference + +This page annotates the [RabbitMQ JMS Client](./jms-client.html) implementation +of the JMS 1.1 API. + +You can download the JMS 1.1 specification and API documentation +from the [Oracle Technology Network Web site](http://www.oracle.com/technetwork/java/docs-136352.html). + +The Compliance Test Suite the JMS Client uses is +[available on GitHub](https://github.com/rabbitmq/rabbitmq-jms-cts). + +## Connection Factory Interfaces + +### ConnectionFactory + +
Connection CreateConnection() |
+Supported | +
Connection CreateConnection(java.lang.String userName, + java.lang.String password) |
+Supported | +
QueueConnection CreateQueueConnection() |
+Supported | +
QueueConnection CreateQueueConnection(java.lang.String userName, + java.lang.String password) |
+Supported | +
TopicConnection CreateTopicConnection() |
+Supported | +
TopicConnection CreateTopicConnection(java.lang.String userName, + java.lang.String password) |
+Supported | +
XAQueueConnection CreateXAQueueConnection() |
+Not supported | +
XAQueueConnection CreateXAQueueConnection(java.lang.String userName, + java.lang.String password) |
+Not supported | +
XATopicConnection CreateXATopicConnection() |
+Not supported | +
XATopicConnection CreateXATopicConnection(java.lang.String userName, + java.lang.String password) |
+Not supported | +
ServerSession getServerSession() |
+Not supported | +
Session getSession() |
+Not supported | +
void start() |
+Not supported | +
Session createSession(boolean transacted, + int acknowledgeMode) |
+Supported | +
java.lang.String getClientID() |
+Supported | +
void setClientID(java.lang.String clientID) |
+Supported | +
ConnectionMetaData getMetaData() |
+Not yet implemented | +
ExceptionListener getExceptionListener() |
+Supported | +
void setExceptionListener(ExceptionListener listener) |
+Supported | +
void start() |
+Supported | +
void stop() |
+Supported | +
void close() |
+Supported | +
ConnectionConsumer createConnectionConsumer(Destination destination, + java.lang.String messageSelector, + ServerSessionPool sessionPool, + int maxMessages) |
+Not supported | +
ConnectionConsumer createDurableConnectionConsumer(Topic topic, + java.lang.String subscriptionName, + java.lang.String messageSelector, + ServerSessionPool sessionPool, + int maxMessages) |
+Not supported | +
QueueSession createQueueSession(boolean transacted, + int acknowledgeMode) |
+Supported | +
ConnectionConsumer createConnectionConsumer(Queue queue, + java.lang.String messageSelector, + ServerSessionPool sessionPool, + int maxMessages) |
+Not supported | +
TopicSession createTopicSession(boolean transacted, + int acknowledgeMode) |
+Supported | +
ConnectionConsumer createConnectionConsumer(Topic topic, + java.lang.String messageSelector, + ServerSessionPool sessionPool, + int maxMessages) |
+Not supported | +
ConnectionConsumer createDurableConnectionConsumer(Topic topic, + java.lang.String subscriptionName, + java.lang.String messageSelector, + ServerSessionPool sessionPool, + int maxMessages) |
+Not supported | +
XASession createXASession() |
+Not yet implemented | +
Session createSession(boolean transacted, + int acknowledgeMode) |
+Not yet implemented | +
XAQueueSession createXAQueueSession() |
+Not yet implemented | +
QueueSession createQueueSession(boolean transacted, + int acknowledgeMode) |
+Not yet implemented | +
XATopicSession createXATopicSession() |
+Not yet implemented | +
TopicSession createTopicSession(boolean transacted, + int acknowledgeMode) |
+Not yet implemented | +
BytesMessage createBytesMessage() |
+Supported | +
MapMessage createMapMessage() |
+Supported | +
Message createMessage() |
+Supported | +
ObjectMessage createObjectMessage() |
+Supported | +
ObjectMessage createObjectMessage(java.io.Serializable object) |
+Supported | +
StreamMessage createStreamMessage() |
+Supported | +
TextMessage createTextMessage() |
+Supported | +
TextMessage createTextMessage(java.lang.String text) |
+Supported | +
boolean getTransacted() |
+Supported | +
int getAcknowledgeMode() |
+Supported | +
void commit() |
+Supported | +
void rollback() |
+Supported | +
void close() |
+Supported | +
void recover() |
+Supported | +
MessageListener getMessageListener() |
+Supported | +
void setMessageListener(MessageListener listener) |
+Supported | +
void run() |
+Not supported | +
MessageProducer createProducer(Destination destination) |
+Supported | +
MessageConsumer createConsumer(Destination destination) |
+Supported | +
MessageConsumer createConsumer(Destination destination, + java.lang.String messageSelector) |
+Not implemented for non-empty messageSelector | +
MessageConsumer createConsumer(Destination destination, + java.lang.String messageSelector, + boolean NoLocal) |
+Not implemented for non-empty messageSelector, and noLocal accepted but ignored | +
Queue createQueue(java.lang.String queueName) |
+Supported | +
Topic createTopic(java.lang.String topicName) |
+Supported | +
TopicSubscriber createDurableSubscriber(Topic topic, + java.lang.String name) |
+Supported | +
TopicSubscriber createDurableSubscriber(Topic topic, + java.lang.String name, + java.lang.String messageSelector, + boolean noLocal) |
+Supported without NoLocal | +
QueueBrowser createBrowser(Queue queue) |
+Not yet implemented | +
QueueBrowser createBrowser(Queue queue, + java.lang.String messageSelector) |
+Not yet implemented | +
TemporaryQueue createTemporaryQueue() |
+Supported | +
TemporaryTopic createTemporaryTopic() |
+Supported | +
void unsubscribe(java.lang.String name) |
+Supported for durable subscriptions only | +
Topic createTopic(java.lang.String topicName) |
+Supported | +
TopicSubscriber createSubscriber(Topic topic, + java.lang.String messageSelector, + boolean noLocal) |
+NoLocal is not supported | +
TopicSubscriber createSubscriber(Topic topic) |
+Supported | +
TopicSubscriber createDurableSubscriber(Topic topic, + java.lang.String name) |
+Supported | +
Queue createQueue(java.lang.String queueName)) |
+Supported | +
QueueReceiver createReceiver(Queue queue) |
+Supported | +
QueueReceiver createReceiver(Queue queue, + java.lang.String messageSelector) |
+Not yet implemented | +
QueueSender createSender(Queue queue) |
+Supported | +
QueueBrowser createBrowser(Queue queue) |
+Supported | +
QueueBrowser createBrowser(Queue queue, + java.lang.String messageSelector) |
+Supported | +
TemporaryQueue createTemporaryQueue() |
+Supported | +
QueueSession getQueueSession() |
+Not yet implemented | +
Session getSession() |
+Not yet implemented | +
XAResource getXAResource() |
+Not yet implemented | +
boolean getTransacted() |
+Not yet implemented | +
void commit() |
+Not yet implemented | +
void rollback() |
+Not yet implemented | +
TopicSession getTopicSession() |
+Not yet implemented | +
ServerSessionPool getServerSessionPool() |
+Not supported | +
void close() |
+Not Supported | +
void setDisableMessageID(boolean value) |
+Ignored. | +
boolean getDisableMessageID() |
+Ignored. | +
void setDisableMessageTimestamp(boolean value) |
+Ignored. | +
boolean getDisableMessageTimestamp() |
+Ignored. | +
void setDeliveryMode(int deliveryMode) |
+Supported | +
int getDeliveryMode() |
+Supported | +
void setPriority(int defaultPriority) |
+Supported | +
int getPriority() |
+Supported | +
void setTimeToLive(long timeToLive) |
+Supported | +
long getTimeToLive() |
+Supported | +
void setDeliveryDelay(long deliveryDelay) |
+Supported | +
long getDeliveryDelay() |
+Supported | +
Destination getDestination() |
+Supported | +
void close() |
+Supported | +
void send(Message message) |
+Supported | +
void send(Message message, + int deliveryMode, + int priority, + long timeToLive) |
+Supported | +
void send(Destination destination, + Message message) |
+Supported | +
void send(Destination destination, + Message message, + int deliveryMode, + int priority, + long timeToLive) |
+Supported | +
Queue getQueue() |
+Supported | +
void send(Message message) |
+Supported | +
void send(Message message, + int deliveryMode, + int priority, + long timeToLive) |
+Supported | +
void send(Queue queue, + Message message) |
+Supported | +
void send(Queue queue, + Message message, + int deliveryMode, + int priority, + long timeToLive) |
+Supported | +
Topic getTopic() |
+Supported | +
void publish(Message message) |
+Supported | +
void publish(Message message, + int deliveryMode, + int priority, + long timeToLive) |
+Supported | +
void publish(Topic topic, + Message message) |
+Supported | +
void publish(Topic topic, + Message message, + int deliveryMode, + int priority, + long timeToLive) |
+Supported | +
java.lang.String getJMSMessageID() |
+Supported | +
void setJMSMessageID(java.lang.String id) |
+Supported | +
long getJMSTimestamp() |
+Supported | +
void setJMSTimestamp(long timestamp) |
+Supported | +
byte[] getJMSCorrelationIDAsBytes() |
+Supported | +
void setJMSCorrelationIDAsBytes(byte[] correlationID) |
+Supported | +
void setJMSCorrelationID(java.lang.String correlationID) |
+Supported | +
java.lang.String getJMSCorrelationID() |
+Supported | +
Destination getJMSReplyTo() |
+Supported | +
void setJMSReplyTo(Destination replyTo) |
+Supported | +
Destination getJMSDestination() |
+Supported | +
void setJMSDestination(Destination destination) |
+Supported | +
int getJMSDeliveryMode() |
+Supported | +
void setJMSDeliveryMode(int deliveryMode) |
+Supported | +
boolean getJMSRedelivered() |
+Supported | +
void setJMSRedelivered(boolean redelivered) |
+Supported | +
java.lang.String getJMSType() |
+Supported | +
void setJMSType(java.lang.String type) |
+Supported | +
long getJMSExpiration() |
+Supported | +
void setJMSExpiration(long expiration) |
+Supported | +
long getJMSDeliveryTime() |
+Supported | +
void setJMSDeliveryTime(long deliveryTime) |
+Supported | +
int getJMSPriority() |
+Supported | +
void setJMSPriority(int priority) |
+Supported | +
void clearProperties() |
+Supported | +
boolean propertyExists(java.lang.String name) |
+Supported | +
boolean getBooleanProperty(java.lang.String name) |
+Supported | +
byte getByteProperty(java.lang.String name) |
+Supported | +
short getShortProperty(java.lang.String name) |
+Supported | +
int getIntProperty(java.lang.String name) |
+Supported | +
long getLongProperty(java.lang.String name) |
+Supported | +
float getFloatProperty(java.lang.String name) |
+Supported | +
double getDoubleProperty(java.lang.String name) |
+Supported | +
java.lang.String getStringProperty(java.lang.String name) |
+Supported | +
java.lang.Object getObjectProperty(java.lang.String name) |
+Supported | +
java.util.Enumeration getPropertyNames() |
+Supported | +
void setBooleanProperty(java.lang.String name, + boolean value) |
+Supported | +
void setShortProperty(java.lang.String name, + short value) |
+Supported | +
void setIntProperty(java.lang.String name, + int value) |
+Supported | +
void setLongProperty(java.lang.String name, + long value) |
+Supported | +
void setFloatProperty(java.lang.String name, + float value) |
+Supported | +
void setDoubleProperty(java.lang.String name, + double value) |
+Supported | +
void setStringProperty(java.lang.String name, + java.lang.String value) |
+Supported | +
void setObjectProperty(java.lang.String name, + java.lang.Object value) |
+Supported | +
void acknowledge() |
+Supported | +
void clearBody() |
+Supported | +
long getBodyLength() |
+Supported | +
boolean readBoolean() |
+Supported | +
byte readByte() |
+Supported | +
int readUnsignedByte() |
+Supported | +
short readShort() |
+Supported | +
int readUnsignedShort() |
+Supported | +
char readChar() |
+Supported | +
int readInt() |
+Supported | +
long readLong() |
+Supported | +
float readFloat() |
+Supported | +
double readDouble() |
+Supported | +
java.lang.String readUTF() |
+Supported | +
int readBytes(byte[] value) |
+Supported | +
int readBytes(byte[] value, + int length) |
+Supported | +
void writeBoolean(boolean value) |
+Supported | +
void writeByte(byte value) |
+Supported | +
void writeShort(short value) |
+Supported | +
void writeChar(char value) |
+Supported | +
void writeInt(int value) |
+Supported | +
void writeLong(long value) |
+Supported | +
void writeFloat(float value) |
+Supported | +
void writeDouble(double value) |
+Supported | +
void writeUTF(java.lang.String value) |
+Supported | +
void writeBytes(byte[] value) |
+Supported | +
void writeBytes(byte[] value, + int offset, + int length) |
+Supported | +
void writeObject(java.lang.Object value) |
+Supported | +
void reset() |
+Supported | +
boolean getBoolean(java.lang.String name) |
+Supported | +
byte getByte(java.lang.String name) |
+Supported | +
short getShort(java.lang.String name) |
+Supported | +
char getChar(java.lang.String name) |
+Supported | +
int getInt(java.lang.String name) |
+Supported | +
long getLong(java.lang.String name) |
+Supported | +
float getFloat(java.lang.String name) |
+Supported | +
double getDouble(java.lang.String name) |
+Supported | +
java.lang.String getString(java.lang.String name) |
+Supported | +
byte[] getBytes(java.lang.String name) |
+Supported | +
java.lang.Object getObject(java.lang.String name) |
+Supported | +
java.util.Enumeration getMapNames() |
+Supported | +
void setBoolean(java.lang.String name, + boolean value) |
+Supported | +
void setByte(java.lang.String name, + byte value) |
+Supported | +
void setShort(java.lang.String name, + short value) |
+Supported | +
void setChar(java.lang.String name, + char value) |
+Supported | +
void setInt(java.lang.String name, + int value) |
+Supported | +
void setLong(java.lang.String name, + long value) |
+Supported | +
void setFloat(java.lang.String name, + float value) |
+Supported | +
void setDouble(java.lang.String name, + double value) |
+Supported | +
void setString(java.lang.String name, + java.lang.String value) |
+Supported | +
void setBytes(java.lang.String name, + byte[] value) |
+Supported | +
void setBytes(java.lang.String name, + byte[] value, + int offset, + int length) |
+Supported | +
void setObject(java.lang.String name, + java.lang.Object value) |
+Supported | +
boolean itemExists(java.lang.String name) |
+Supported | +
void setObject(java.io.Serializable object) |
+Supported | +
java.io.Serializable getObject() |
+Supported | +
boolean readBoolean() |
+Supported | +
byte readByte() |
+Supported | +
short readShort() |
+Supported | +
char readChar() |
+Supported | +
int readInt() |
+Supported | +
long readLong() |
+Supported | +
float readFloat() |
+Supported | +
double readDouble() |
+Supported | +
java.lang.String readString() |
+Supported | +
int readBytes(byte[] value) |
+Supported | +
java.lang.Object readObject() |
+Supported | +
void writeBoolean(boolean value) |
+Supported | +
oid writeByte(byte value) |
+Supported | +
void writeShort(short value) |
+Supported | +
void writeChar(char value) |
+Supported | +
void writeInt(int value) |
+Supported | +
void writeLong(long value) |
+Supported | +
void writeFloat(float value) |
+Supported | +
void writeDouble(double value) |
+Supported | +
void writeString(java.lang.String value) |
+Supported | +
void writeBytes(byte[] value) |
+Supported | +
void writeBytes(byte[] value, + int offset, + int length) |
+Supported | +
void writeObject(java.lang.Object value) |
+Supported | +
void reset() |
+Supported | +
void setText(java.lang.String string) |
+Supported | +
java.lang.String getText() |
+Supported | +
java.lang.String getMessageSelector() |
+Supported | +
MessageListener getMessageListener() |
+Supported | +
void setMessageListener(MessageListener listener) |
+Supported | +
Message receive() |
+Supported | +
Message receive(long timeout) |
+Supported | +
Message receiveNoWait() |
+Supported | +
void close() |
+Supported | +
Queue getQueue() |
+Supported | +
Topic getTopic() |
+Supported | +
boolean getNoLocal() |
+NoLocal is not supported | +
java.lang.String getQueueName() |
+Supported | +
java.lang.String toString() |
+Supported | +
void delete() |
+Supported | +
java.lang.String getTopicName() |
+Supported | +
java.lang.String toString() |
+Supported | +
void delete() |
+Supported | +
Queue getQueue() |
+Supported | +
java.lang.String getMessageSelector() |
+Supported | +
java.util.Enumeration getEnumeration() |
+Supported | +
void close() |
+Supported | +