You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by rg...@apache.org on 2007/04/04 17:20:31 UTC

svn commit: r525535 - in /incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store: MessageStore.java StoreContext.java

Author: rgreig
Date: Wed Apr  4 08:20:30 2007
New Revision: 525535

URL: http://svn.apache.org/viewvc?view=rev&rev=525535
Log:
Added comments and logging to track down bug.

Modified:
    incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/MessageStore.java
    incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/StoreContext.java

Modified: incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/MessageStore.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/MessageStore.java?view=diff&rev=525535&r1=525534&r2=525535
==============================================================================
--- incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/MessageStore.java (original)
+++ incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/MessageStore.java Wed Apr  4 08:20:30 2007
@@ -21,73 +21,241 @@
 package org.apache.qpid.server.store;
 
 import org.apache.commons.configuration.Configuration;
+
 import org.apache.qpid.AMQException;
 import org.apache.qpid.framing.AMQShortString;
 import org.apache.qpid.framing.FieldTable;
 import org.apache.qpid.framing.abstraction.ContentChunk;
+import org.apache.qpid.server.exchange.Exchange;
 import org.apache.qpid.server.queue.AMQQueue;
 import org.apache.qpid.server.queue.MessageMetaData;
 import org.apache.qpid.server.virtualhost.VirtualHost;
-import org.apache.qpid.server.exchange.Exchange;
 
+/**
+ * MessageStore defines the interface to a storage area, which can be used to preserve the state of messages, queues
+ * and exchanges in a transactional manner.
+ *
+ * <p/>All message store, remove, enqueue and dequeue operations are carried out against a {@link StoreContext} which
+ * encapsulates the transactional context they are performed in. Many such operations can be carried out in a single
+ * transaction.
+ *
+ * <p/>The storage and removal of queues and exchanges, are not carried out in a transactional context.
+ *
+ * <p/><table id="crc"><caption>CRC Card</caption>
+ * <tr><th> Responsibilities
+ * <tr><td> Accept transaction boundary demarcations: Begin, Commit, Abort.
+ * <tr><td> Store and remove queues.
+ * <tr><td> Store and remove exchanges.
+ * <tr><td> Store and remove messages.
+ * <tr><td> Bind and unbind queues to exchanges.
+ * <tr><td> Enqueue and dequeue messages to queues.
+ * <tr><td> Generate message identifiers.
+ * </table>
+ */
 public interface MessageStore
 {
     /**
      * Called after instantiation in order to configure the message store. A particular implementation can define
      * whatever parameters it wants.
-     * @param virtualHost the virtual host using by this store
-     * @param base the base element identifier from which all configuration items are relative. For example, if the base
-     * element is "store", the all elements used by concrete classes will be "store.foo" etc.
-     * @param config the apache commons configuration object
-     * @throws Exception if an error occurs that means the store is unable to configure itself
+     *
+     * @param virtualHost The virtual host using by this store
+     * @param base        The base element identifier from which all configuration items are relative. For example, if
+     *                    the base element is "store", the all elements used by concrete classes will be "store.foo" etc.
+     * @param config      The apache commons configuration object.
+     *
+     * @throws Exception If any error occurs that means the store is unable to configure itself.
      */
     void configure(VirtualHost virtualHost, String base, Configuration config) throws Exception;
 
     /**
      * Called to close and cleanup any resources used by the message store.
-     * @throws Exception if close fails
+     *
+     * @throws Exception If the close fails.
      */
     void close() throws Exception;
 
+    /**
+     * Removes the specified message from the store in the given transactional store context.
+     *
+     * @param storeContext The transactional context to remove the message in.
+     * @param messageId    Identifies the message to remove.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void removeMessage(StoreContext storeContext, Long messageId) throws AMQException;
 
+    /**
+     * Makes the specified exchange persistent.
+     *
+     * @param exchange The exchange to persist.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void createExchange(Exchange exchange) throws AMQException;
 
+    /**
+     * Removes the specified persistent exchange.
+     *
+     * @param exchange The exchange to remove.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void removeExchange(Exchange exchange) throws AMQException;
 
+    /**
+     * Binds the specified queue to an exchange with a routing key.
+     *
+     * @param exchange   The exchange to bind to.
+     * @param routingKey The routing key to bind by.
+     * @param queue      The queue to bind.
+     * @param args       Additional parameters.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void bindQueue(Exchange exchange, AMQShortString routingKey, AMQQueue queue, FieldTable args) throws AMQException;
 
+    /**
+     * Unbinds the specified from an exchange under a particular routing key.
+     *
+     * @param exchange   The exchange to unbind from.
+     * @param routingKey The routing key to unbind.
+     * @param queue      The queue to unbind.
+     * @param args       Additonal parameters.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void unbindQueue(Exchange exchange, AMQShortString routingKey, AMQQueue queue, FieldTable args) throws AMQException;
 
-
+    /**
+     * Makes the specified queue persistent.
+     *
+     * @param queue The queue to store.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void createQueue(AMQQueue queue) throws AMQException;
 
+    /**
+     * Removes the specified queue from the persistent store.
+     *
+     * @param name The queue to remove.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void removeQueue(AMQShortString name) throws AMQException;
 
+    /**
+     * Places a message onto a specified queue, in a given transactional context.
+     *
+     * @param context   The transactional context for the operation.
+     * @param name      The name of the queue to place the message on.
+     * @param messageId The message to enqueue.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void enqueueMessage(StoreContext context, AMQShortString name, Long messageId) throws AMQException;
 
+    /**
+     * Extracts a message from a specified queue, in a given transactional context.
+     *
+     * @param context   The transactional context for the operation.
+     * @param name      The name of the queue to take the message from.
+     * @param messageId The message to dequeue.
+     *
+     * @throws AMQException If the operation fails for any reason, or if the specified message does not exist.
+     */
     void dequeueMessage(StoreContext context, AMQShortString name, Long messageId) throws AMQException;
 
+    /**
+     * Begins a transactional context.
+     *
+     * @param context The transactional context to begin.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void beginTran(StoreContext context) throws AMQException;
 
+    /**
+     * Commits all operations performed within a given transactional context.
+     *
+     * @param context The transactional context to commit all operations for.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void commitTran(StoreContext context) throws AMQException;
 
+    /**
+     * Abandons all operations performed within a given transactional context.
+     *
+     * @param context The transactional context to abandon.
+     *
+     * @throws AMQException If the operation fails for any reason.
+     */
     void abortTran(StoreContext context) throws AMQException;
 
+    /**
+     * Tests a transactional context to see if it has been begun but not yet committed or aborted.
+     *
+     * @param context The transactional context to test.
+     *
+     * @return <tt>true</tt> if the transactional context is live, <tt>false</tt> otherwise.
+     */
     boolean inTran(StoreContext context);
 
     /**
      * Return a valid, currently unused message id.
-     * @return a message id
+     *
+     * @return A fresh message id.
      */
     Long getNewMessageId();
 
-    void storeContentBodyChunk(StoreContext context, Long messageId, int index, ContentChunk contentBody, boolean lastContentBody) throws AMQException;
+    /**
+     * Stores a chunk of message data.
+     *
+     * @param context         The transactional context for the operation.
+     * @param messageId       The message to store the data for.
+     * @param index           The index of the data chunk.
+     * @param contentBody     The content of the data chunk.
+     * @param lastContentBody Flag to indicate that this is the last such chunk for the message.
+     *
+     * @throws AMQException If the operation fails for any reason, or if the specified message does not exist.
+     */
+    void storeContentBodyChunk(StoreContext context, Long messageId, int index, ContentChunk contentBody,
+        boolean lastContentBody) throws AMQException;
 
+    /**
+     * Stores message meta-data.
+     *
+     * @param context         The transactional context for the operation.
+     * @param messageId       The message to store the data for.
+     * @param messageMetaData The message meta data to store.
+     *
+     * @throws AMQException If the operation fails for any reason, or if the specified message does not exist.
+     */
     void storeMessageMetaData(StoreContext context, Long messageId, MessageMetaData messageMetaData) throws AMQException;
 
+    /**
+     * Retrieves message meta-data.
+     *
+     * @param context   The transactional context for the operation.
+     * @param messageId The message to get the meta-data for.
+     *
+     * @return The message meta data.
+     *
+     * @throws AMQException If the operation fails for any reason, or if the specified message does not exist.
+     */
     MessageMetaData getMessageMetaData(StoreContext context, Long messageId) throws AMQException;
 
+    /**
+     * Retrieves a chunk of message data.
+     *
+     * @param context   The transactional context for the operation.
+     * @param messageId The message to get the data chunk for.
+     * @param index     The offset index of the data chunk within the message.
+     *
+     * @return A chunk of message data.
+     *
+     * @throws AMQException If the operation fails for any reason, or if the specified message does not exist.
+     */
     ContentChunk getContentBodyChunk(StoreContext context, Long messageId, int index) throws AMQException;
-
 }

Modified: incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/StoreContext.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/StoreContext.java?view=diff&rev=525535&r1=525534&r2=525535
==============================================================================
--- incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/StoreContext.java (original)
+++ incubator/qpid/branches/M2/java/broker/src/main/java/org/apache/qpid/server/store/StoreContext.java Wed Apr  4 08:20:30 2007
@@ -22,16 +22,14 @@
 
 import org.apache.log4j.Logger;
 
-
 /**
  * A context that the store can use to associate with a transactional context. For example, it could store
  * some kind of txn id.
- * 
+ *
  * @author Apache Software Foundation
  */
 public class StoreContext
 {
-
     private static final Logger _logger = Logger.getLogger(StoreContext.class);
 
     private String _name;
@@ -54,7 +52,17 @@
 
     public void setPayload(Object payload)
     {
-        _logger.debug("["+_name+"] Setting payload: " + payload);
+        _logger.debug("public void setPayload(Object payload = " + payload + "): called");
         _payload = payload;
+    }
+
+    /**
+     * Prints out the transactional context as a string, mainly for debugging purposes.
+     *
+     * @return The transactional context as a string.
+     */
+    public String toString()
+    {
+        return "<_name = " + _name + ", _payload = " + _payload + ">";
     }
 }