You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cm...@apache.org on 2009/06/19 02:53:31 UTC

svn commit: r786346 - in /activemq/sandbox/activemq-flow/activemq-queue/src: main/java/org/apache/activemq/queue/ test/resources/META-INF/services/org/apache/activemq/wireformat/

Author: cmacnaug
Date: Fri Jun 19 00:53:31 2009
New Revision: 786346

URL: http://svn.apache.org/viewvc?rev=786346&view=rev
Log:
Refactoring queue package to allow Subscriptions for all queue types

Added:
    activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/default
Removed:
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IAsynchronousFlowSource.java
    activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/test
Modified:
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/AbstractFlowQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePersistentQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePriorityQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusiveQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IFlowQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/MultiFlowQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/PartitionedQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedPriorityQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueue.java
    activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueueOld.java
    activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto
    activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto2

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/AbstractFlowQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/AbstractFlowQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/AbstractFlowQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/AbstractFlowQueue.java Fri Jun 19 00:53:31 2009
@@ -46,6 +46,7 @@
         }
     };
     protected boolean started;
+    protected Subscription<E> sub;
 
     AbstractFlowQueue() {
         super();
@@ -59,16 +60,6 @@
         this.listener = listener;
     }
 
-    public void add(E elem, ISourceController<?> source) {
-        getSinkController(elem, source).add(elem, source);
-    }
-
-    public boolean offer(E elem, ISourceController<?> source) {
-        return getSinkController(elem, source).offer(elem, source);
-    }
-
-    protected abstract ISinkController<E> getSinkController(E elem, ISourceController<?> source);
-
     public final boolean dispatch() {
 
         // while (pollingDispatch());
@@ -93,9 +84,10 @@
     public synchronized void stop() {
         started = false;
     }
-    
+
     /**
      * Calls stop and cleans up resources associated with the queue.
+     * 
      * @param sync
      */
     public void shutdown(boolean sync) {
@@ -104,15 +96,45 @@
         synchronized (this) {
             dc = dispatchContext;
             dispatchContext = null;
-            
+
         }
-        
+
         if (dc != null) {
             dc.close(sync);
         }
     }
 
     /**
+     * Adds a subscription to the queue. When the queue is started and elements
+     * are available, they will be given to the subscription.
+     * 
+     * @param sub
+     *            The subscription to add to the queue.
+     */
+    public synchronized void addSubscription(Subscription<E> sub) {
+        if (sub == null) {
+            this.sub = sub;
+        } else if (sub != sub) {
+            //TODO change this to a checked exception.
+            throw new IllegalStateException("Sub already connected");
+        }
+    }
+
+    /**
+     * Removes a subscription from the queue.
+     * 
+     * @param sub
+     *            The subscription to remove.
+     */
+    public synchronized boolean removeSubscription(Subscription<E> sub) {
+        if (this.sub == sub) {
+            sub = null;
+            return true;
+        }
+        return false;
+    }
+
+    /**
      * Sets an asynchronous dispatcher for this source. As elements become
      * available they will be dispatched to the worker pool.
      * 
@@ -128,7 +150,7 @@
         super.setFlowExecutor(dispatcher.createPriorityExecutor(dispatcher.getDispatchPriorities() - 1));
     }
 
-    public synchronized final void setDispatchPriority(int priority) {
+    public synchronized void setDispatchPriority(int priority) {
         dispatchPriority = priority;
         if (dispatchContext != null) {
             dispatchContext.updatePriority(priority);
@@ -197,5 +219,4 @@
     public String toString() {
         return getResourceName();
     }
-
 }

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePersistentQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePersistentQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePersistentQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePersistentQueue.java Fri Jun 19 00:53:31 2009
@@ -183,9 +183,12 @@
         }
     }
 
-    public synchronized void removeSubscription(Subscription<E> sub) {
+    public synchronized boolean removeSubscription(Subscription<E> sub) {
         if (sub == subscription) {
             sub = null;
+            return true;
+        } else {
+            return false;
         }
     }
 

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePriorityQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePriorityQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePriorityQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusivePriorityQueue.java Fri Jun 19 00:53:31 2009
@@ -58,10 +58,15 @@
 
     }
 
-    protected final ISinkController<E> getSinkController(E elem, ISourceController<?> source) {
-        return controller;
+    
+    public void add(E elem, ISourceController<?> source) {
+        controller.add(elem, source);
     }
 
+    public boolean offer(E elem, ISourceController<?> source) {
+        return controller.offer(elem, source);
+    }
+    
     /**
      * Called when the controller accepts a message for this queue.
      */
@@ -86,7 +91,12 @@
     public boolean pollingDispatch() {
         E elem = poll();
         if (elem != null) {
-            drain.drain(elem, controller);
+            if (sub != null) {
+                sub.add(elem, controller, null);
+            } else {
+                //TODO remove drain:
+                drain.drain(elem, controller);
+            }
             return true;
         } else {
             return false;

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusiveQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusiveQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusiveQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/ExclusiveQueue.java Fri Jun 19 00:53:31 2009
@@ -42,8 +42,12 @@
         super.onFlowOpened(controller);
     }
 
-    protected final ISinkController<E> getSinkController(E elem, ISourceController<?> source) {
-        return controller;
+    public void add(E elem, ISourceController<?> source) {
+        controller.add(elem, source);
+    }
+
+    public boolean offer(E elem, ISourceController<?> source) {
+        return controller.offer(elem, source);
     }
 
     /**
@@ -68,7 +72,12 @@
         E elem = poll();
 
         if (elem != null) {
-            drain.drain(elem, controller);
+            if (sub != null) {
+                sub.add(elem, controller, null);
+            } else {
+                drain.drain(elem, controller);
+            }
+
             return true;
         } else {
             return false;

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IFlowQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IFlowQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IFlowQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IFlowQueue.java Fri Jun 19 00:53:31 2009
@@ -16,9 +16,10 @@
  */
 package org.apache.activemq.queue;
 
+import org.apache.activemq.dispatch.IDispatcher;
 import org.apache.activemq.flow.IFlowRelay;
 
-public interface IFlowQueue<E> extends IBlockingFlowSource<E>, IPollableFlowSource<E>, IAsynchronousFlowSource<E>, IFlowRelay<E> {
+public interface IFlowQueue<E> extends IBlockingFlowSource<E>, IPollableFlowSource<E>, IFlowRelay<E> {
 
     public interface FlowQueueListener {
         
@@ -33,5 +34,40 @@
 
     public void setFlowQueueListener(FlowQueueListener listener);
     
+    /**
+     * Adds a subscription to the queue. When the queue is started and elements
+     * are available, they will be given to the subscription.
+     * 
+     * @param sub
+     *            The subscription to add to the queue.
+     */
+    public void addSubscription(Subscription<E> sub);
+
+    /**
+     * Removes a subscription from the queue.
+     * 
+     * @param sub
+     *            The subscription to remove.
+     */
+    public boolean removeSubscription(Subscription<E> sub);
+    
+    /**
+     * Sets the dispatcher for the queue.
+     * 
+     * @param dispatcher
+     *            The dispatcher to be used by the queue.
+     */
+    public void setDispatcher(IDispatcher dispatcher);
+
+    /**
+     * Sets the base dispatch priority for the queue. Setting to higher value
+     * will increase the preference with which the dispatcher dispatches the
+     * queue. If the queue itself is priority based, the queue may further
+     * increase it's dispatch priority based on the priority of elements that it
+     * holds.
+     * 
+     * @param priority
+     *            The base priority for the queue
+     */
     public void setDispatchPriority(int priority);
 }

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/IQueue.java Fri Jun 19 00:53:31 2009
@@ -21,7 +21,7 @@
 import org.apache.activemq.queue.QueueStore.PersistentQueue;
 import org.apache.activemq.util.Mapper;
 
-public interface IQueue<K, V> extends IFlowSink<V>, PersistentQueue<K, V> {
+public interface IQueue<K, V> extends IFlowQueue<V>, PersistentQueue<K, V> {
 
     /**
      * @return the number of elements currently held by the queue.
@@ -34,23 +34,6 @@
     public long getEnqueuedSize();
 
     /**
-     * Adds a subscription to the queue. When the queue is started and elements
-     * are available, they will be given to the subscription.
-     * 
-     * @param sub
-     *            The subscription to add to the queue.
-     */
-    public void addSubscription(Subscription<V> sub);
-
-    /**
-     * Removes a subscription from the queue.
-     * 
-     * @param sub
-     *            The subscription to remove.
-     */
-    public boolean removeSubscription(Subscription<V> sub);
-
-    /**
      * Sets a mapper returning the expiration time for elements in this queue. A
      * positive value indicates that the message has an expiration time.
      * 

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/MultiFlowQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/MultiFlowQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/MultiFlowQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/MultiFlowQueue.java Fri Jun 19 00:53:31 2009
@@ -47,15 +47,23 @@
         // so this shouldn't be called.
         throw new UnsupportedOperationException();
     }
+    
+    public synchronized void add(E elem, ISourceController<?> source) {
+        getQueue(elem, source).controller.add(elem, source);
+    }
 
-    protected synchronized final ISinkController<E> getSinkController(E elem, ISourceController<?> source) {
+    public synchronized boolean offer(E elem, ISourceController<?> source) {
+        return getQueue(elem, source).controller.offer(elem, source);
+    }
+
+    private synchronized final SingleFlowQueue getQueue(E elem, ISourceController<?> source) {
         SingleFlowQueue queue = flowQueues.get(source.getFlow());
         if (queue == null) {
             queue = new SingleFlowQueue(source.getFlow(), new SizeLimiter<E>(perFlowWindow, resumeThreshold));
             flowQueues.put(source.getFlow(), queue);
             super.onFlowOpened(queue.controller);
         }
-        return queue.controller;
+        return queue;
     }
     
     public boolean pollingDispatch() {
@@ -78,7 +86,11 @@
             queue.getList().rotate();
         }
 
-        drain.drain(elem, queue.controller);
+        if (sub != null) {
+            sub.add(elem, queue.controller, null);
+        } else {
+            drain.drain(elem, queue.controller);
+        }
         return true;
     }
 

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/PartitionedQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/PartitionedQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/PartitionedQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/PartitionedQueue.java Fri Jun 19 00:53:31 2009
@@ -27,7 +27,7 @@
 import org.apache.activemq.protobuf.AsciiBuffer;
 import org.apache.activemq.util.Mapper;
 
-abstract public class PartitionedQueue<K, V> extends AbstractLimitedFlowResource<V> implements IPartitionedQueue<K, V> {
+abstract public class PartitionedQueue<K, V> extends AbstractFlowQueue<V> implements IPartitionedQueue<K, V> {
 
     private HashSet<Subscription<V>> subscriptions = new HashSet<Subscription<V>>();
     private HashMap<Integer, IQueue<K, V>> partitions = new HashMap<Integer, IQueue<K, V>>();
@@ -247,4 +247,37 @@
             throw new IllegalStateException(this + " is shutdown");
         }
     }
+    
+    /* (non-Javadoc)
+     * @see org.apache.activemq.queue.IPollableFlowSource#isDispatchReady()
+     */
+    public boolean isDispatchReady() {
+        // TODO Auto-generated method stub
+        throw new UnsupportedOperationException();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.queue.IPollableFlowSource#poll()
+     */
+    public V poll() {
+        // TODO Auto-generated method stub
+        throw new UnsupportedOperationException();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.queue.IPollableFlowSource#pollingDispatch()
+     */
+    public boolean pollingDispatch() {
+        // TODO Auto-generated method stub
+        throw new UnsupportedOperationException();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.flow.ISinkController.FlowControllable#flowElemAccepted(org.apache.activemq.flow.ISourceController, java.lang.Object)
+     */
+    public void flowElemAccepted(ISourceController<V> source, V elem) {
+        // TODO Remove
+        throw new UnsupportedOperationException();
+        
+    }
 }

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedPriorityQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedPriorityQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedPriorityQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedPriorityQueue.java Fri Jun 19 00:53:31 2009
@@ -27,7 +27,7 @@
 import org.apache.activemq.protobuf.AsciiBuffer;
 import org.apache.activemq.util.Mapper;
 
-public class SharedPriorityQueue<K, V> extends AbstractLimitedFlowResource<V> implements IPartitionedQueue<K, V> {
+public class SharedPriorityQueue<K, V> extends AbstractFlowQueue<V> implements IPartitionedQueue<K, V> {
 
     private final HashSet<Subscription<V>> subscriptions = new HashSet<Subscription<V>>();
     private final Mapper<Integer, V> priorityMapper;
@@ -142,10 +142,8 @@
         this.expirationMapper = expirationMapper;
     }
 
-    public void setResourceName(String resourceName) {
-        super.setResourceName(resourceName);
-    }
 
+    @Override
     public void addSubscription(Subscription<V> sub) {
         synchronized (this) {
             checkShutdown();
@@ -157,7 +155,8 @@
             }
         }
     }
-
+    
+    @Override
     public boolean removeSubscription(Subscription<V> sub) {
         synchronized (this) {
             if (subscriptions.remove(sub)) {
@@ -266,4 +265,37 @@
         }
     }
 
+    /* (non-Javadoc)
+     * @see org.apache.activemq.queue.IPollableFlowSource#isDispatchReady()
+     */
+    public boolean isDispatchReady() {
+        // TODO Auto-generated method stub
+        throw new UnsupportedOperationException();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.queue.IPollableFlowSource#poll()
+     */
+    public V poll() {
+        // TODO Auto-generated method stub
+        throw new UnsupportedOperationException();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.queue.IPollableFlowSource#pollingDispatch()
+     */
+    public boolean pollingDispatch() {
+        // TODO Auto-generated method stub
+        throw new UnsupportedOperationException();
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.flow.ISinkController.FlowControllable#flowElemAccepted(org.apache.activemq.flow.ISourceController, java.lang.Object)
+     */
+    public void flowElemAccepted(ISourceController<V> source, V elem) {
+        // TODO Remove
+        throw new UnsupportedOperationException();
+        
+    }
+
 }

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueue.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueue.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueue.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueue.java Fri Jun 19 00:53:31 2009
@@ -246,11 +246,6 @@
         this.expirationMapper = expirationMapper;
     }
 
-    @Override
-    protected ISinkController<V> getSinkController(V elem, ISourceController<?> source) {
-        return inputController;
-    }
-
     public V poll() {
         throw new UnsupportedOperationException("poll not supported for shared queue");
     }

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueueOld.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueueOld.java?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueueOld.java (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/main/java/org/apache/activemq/queue/SharedQueueOld.java Fri Jun 19 00:53:31 2009
@@ -164,10 +164,14 @@
         //not implemented.
     }
 
-    protected final ISinkController<V> getSinkController(V elem, ISourceController<?> source) {
-        return sinkController;
+    public void add(V elem, ISourceController<?> source) {
+        sinkController.add(elem, source);
     }
 
+    public boolean offer(V elem, ISourceController<?> source) {
+        return sinkController.offer(elem, source);
+    }
+    
     /**
      * Called when the controller accepts a message for this queue.
      */

Added: activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/default
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/default?rev=786346&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/default (added)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/default Fri Jun 19 00:53:31 2009
@@ -0,0 +1,17 @@
+## ---------------------------------------------------------------------------
+## Licensed to the Apache Software Foundation (ASF) under one or more
+## contributor license agreements.  See the NOTICE file distributed with
+## this work for additional information regarding copyright ownership.
+## The ASF licenses this file to You under the Apache License, Version 2.0
+## (the "License"); you may not use this file except in compliance with
+## the License.  You may obtain a copy of the License at
+## 
+## http://www.apache.org/licenses/LICENSE-2.0
+## 
+## Unless required by applicable law or agreed to in writing, software
+## distributed under the License is distributed on an "AS IS" BASIS,
+## WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+## See the License for the specific language governing permissions and
+## limitations under the License.
+## ---------------------------------------------------------------------------
+class=org.apache.activemq.queue.perf.Proto2WireFormatFactory

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto Fri Jun 19 00:53:31 2009
@@ -14,4 +14,4 @@
 ## See the License for the specific language governing permissions and
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
-class=org.apache.activemq.flow.ProtoWireFormatFactory
+class=org.apache.activemq.queue.perf.ProtoWireFormatFactory

Modified: activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto2
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto2?rev=786346&r1=786345&r2=786346&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto2 (original)
+++ activemq/sandbox/activemq-flow/activemq-queue/src/test/resources/META-INF/services/org/apache/activemq/wireformat/proto2 Fri Jun 19 00:53:31 2009
@@ -14,4 +14,4 @@
 ## See the License for the specific language governing permissions and
 ## limitations under the License.
 ## ---------------------------------------------------------------------------
-class=org.apache.activemq.flow.Proto2WireFormatFactory
+class=org.apache.activemq.queue.perf.Proto2WireFormatFactory