You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2009/03/18 16:00:23 UTC

svn commit: r755611 - in /activemq/sandbox/activemq-flow/src: main/java/org/apache/activemq/broker/ main/java/org/apache/activemq/broker/openwire/ main/java/org/apache/activemq/broker/protocol/ main/java/org/apache/activemq/broker/stomp/ main/java/org/...

Author: chirino
Date: Wed Mar 18 15:00:22 2009
New Revision: 755611

URL: http://svn.apache.org/viewvc?rev=755611&view=rev
Log:
Made protocol handlers discoverable so that protocol extensions can be more easily added.

Added:
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandler.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandlerFactory.java
    activemq/sandbox/activemq-flow/src/main/resources/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/openwire
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/stomp
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/default
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/multi
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/openwire
    activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/stomp
Removed:
    activemq/sandbox/activemq-flow/src/test/resources/META-INF/services/org/apache/activemq/wireformat/multi
Modified:
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/BrokerConnection.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/openwire/OpenwireProtocolHandler.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/stomp/StompProtocolHandler.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableOpenWireFormatFactory.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableStompWireFormatFactory.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableWireFormatFactory.java
    activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/MultiWireFormatFactory.java

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/BrokerConnection.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/BrokerConnection.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/BrokerConnection.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/BrokerConnection.java Wed Mar 18 15:00:22 2009
@@ -17,29 +17,18 @@
 package org.apache.activemq.broker;
 
 import java.beans.ExceptionListener;
-import java.io.IOException;
 
 import org.apache.activemq.Connection;
-import org.apache.activemq.Service;
-import org.apache.activemq.broker.openwire.OpenwireProtocolHandler;
-import org.apache.activemq.broker.stomp.StompProtocolHandler;
-import org.apache.activemq.openwire.OpenWireFormat;
-import org.apache.activemq.transport.stomp.StompWireFormat;
-import org.apache.activemq.wireformat.WireFormat;
+import org.apache.activemq.broker.protocol.ProtocolHandler;
+import org.apache.activemq.broker.protocol.ProtocolHandlerFactory;
+import org.apache.activemq.util.IOExceptionSupport;
+import org.apache.activemq.wireformat.MultiWireFormatFactory.WireFormatConnected;
 
 public class BrokerConnection extends Connection {
     
     protected Broker broker;
     private ProtocolHandler protocolHandler;
 
-    public interface ProtocolHandler extends Service {
-        public void setConnection(BrokerConnection connection);
-        public void onCommand(Object command);
-        public void onException(Exception error);
-        public void setWireFormat(WireFormat wf);
-    }
-
-    
     public BrokerConnection() {
         setExceptionListener(new ExceptionListener(){
             public void exceptionThrown(Exception error) {
@@ -71,20 +60,17 @@
             protocolHandler.onCommand(command);
         } else {
             try {
-                
-                // TODO: need to make this more extensible and dynamic.  Perhaps 
-                // we should lookup the ProtocolHandler via a FactoryFinder
-                WireFormat wf = (WireFormat) command;
-                if( wf.getClass() == OpenWireFormat.class ) {
-                    protocolHandler = new OpenwireProtocolHandler();
-                } else if( wf.getClass() == StompWireFormat.class ) {
-                    protocolHandler = new StompProtocolHandler();
-                } else {
-                    throw new IOException("No protocol handler available for: "+wf.getClass());
+
+                WireFormatConnected wfconnected = (WireFormatConnected) command;
+                String wfName = wfconnected.getWireFormatFactory().wireformatName();
+                try {
+                    protocolHandler = ProtocolHandlerFactory.createProtocolHandler(wfName);
+                } catch(Exception e) {
+                    throw IOExceptionSupport.create("No protocol handler available for: "+wfName, e);
                 }
                 
                 protocolHandler.setConnection(this);
-                protocolHandler.setWireFormat(wf);
+                protocolHandler.setWireFormat(wfconnected.getWireFormat());
                 protocolHandler.start();
                 
                 setExceptionListener(new ExceptionListener(){

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/openwire/OpenwireProtocolHandler.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/openwire/OpenwireProtocolHandler.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/openwire/OpenwireProtocolHandler.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/openwire/OpenwireProtocolHandler.java Wed Mar 18 15:00:22 2009
@@ -29,7 +29,7 @@
 import org.apache.activemq.broker.Destination;
 import org.apache.activemq.broker.MessageDelivery;
 import org.apache.activemq.broker.Router;
-import org.apache.activemq.broker.BrokerConnection.ProtocolHandler;
+import org.apache.activemq.broker.protocol.ProtocolHandler;
 import org.apache.activemq.command.ActiveMQDestination;
 import org.apache.activemq.command.BrokerId;
 import org.apache.activemq.command.BrokerInfo;

Added: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandler.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandler.java?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandler.java (added)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandler.java Wed Mar 18 15:00:22 2009
@@ -0,0 +1,28 @@
+/**
+ * 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.
+ */
+package org.apache.activemq.broker.protocol;
+
+import org.apache.activemq.Service;
+import org.apache.activemq.broker.BrokerConnection;
+import org.apache.activemq.wireformat.WireFormat;
+
+public interface ProtocolHandler extends Service {
+    public void setConnection(BrokerConnection connection);
+    public void onCommand(Object command);
+    public void onException(Exception error);
+    public void setWireFormat(WireFormat wf);
+}
\ No newline at end of file

Added: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandlerFactory.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandlerFactory.java?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandlerFactory.java (added)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/protocol/ProtocolHandlerFactory.java Wed Mar 18 15:00:22 2009
@@ -0,0 +1,31 @@
+/**
+ * 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.
+ */
+package org.apache.activemq.broker.protocol;
+
+import java.io.IOException;
+
+import org.apache.activemq.util.FactoryFinder;
+
+public class ProtocolHandlerFactory {
+
+    static private final FactoryFinder PROTOCOL_HANDLER_FINDER = new FactoryFinder("META-INF/services/org/apache/activemq/broker/protocol/");
+    
+    public static ProtocolHandler createProtocolHandler(String type) throws IllegalAccessException, InstantiationException, IOException, ClassNotFoundException {
+        return (ProtocolHandler) PROTOCOL_HANDLER_FINDER.newInstance(type);
+    }
+    
+}

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/stomp/StompProtocolHandler.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/stomp/StompProtocolHandler.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/stomp/StompProtocolHandler.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/broker/stomp/StompProtocolHandler.java Wed Mar 18 15:00:22 2009
@@ -28,7 +28,6 @@
 import java.util.Map;
 
 import javax.jms.InvalidSelectorException;
-import javax.jms.JMSException;
 
 import org.apache.activemq.WindowLimiter;
 import org.apache.activemq.broker.BrokerConnection;
@@ -36,11 +35,9 @@
 import org.apache.activemq.broker.Destination;
 import org.apache.activemq.broker.MessageDelivery;
 import org.apache.activemq.broker.Router;
-import org.apache.activemq.broker.BrokerConnection.ProtocolHandler;
+import org.apache.activemq.broker.protocol.ProtocolHandler;
 import org.apache.activemq.command.ActiveMQDestination;
-import org.apache.activemq.command.Message;
 import org.apache.activemq.filter.BooleanExpression;
-import org.apache.activemq.filter.MessageEvaluationContext;
 import org.apache.activemq.flow.Flow;
 import org.apache.activemq.flow.FlowController;
 import org.apache.activemq.flow.IFlowController;

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableOpenWireFormatFactory.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableOpenWireFormatFactory.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableOpenWireFormatFactory.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableOpenWireFormatFactory.java Wed Mar 18 15:00:22 2009
@@ -39,4 +39,8 @@
         return 4+MAGIC.length;
     }
 
+    public String wireformatName() {
+        return "openwire";
+    }
+
 }

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableStompWireFormatFactory.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableStompWireFormatFactory.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableStompWireFormatFactory.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableStompWireFormatFactory.java Wed Mar 18 15:00:22 2009
@@ -60,4 +60,8 @@
         return MAGIC.length+10;
     }
 
+    public String wireformatName() {
+        return "stomp";
+    }
+
 }

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableWireFormatFactory.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableWireFormatFactory.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableWireFormatFactory.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/DiscriminatableWireFormatFactory.java Wed Mar 18 15:00:22 2009
@@ -29,4 +29,5 @@
 
     boolean matchesWireformatHeader(ByteSequence byteSequence);
 
+    String wireformatName();
 }

Modified: activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/MultiWireFormatFactory.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/MultiWireFormatFactory.java?rev=755611&r1=755610&r2=755611&view=diff
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/MultiWireFormatFactory.java (original)
+++ activemq/sandbox/activemq-flow/src/main/java/org/apache/activemq/wireformat/MultiWireFormatFactory.java Wed Mar 18 15:00:22 2009
@@ -27,9 +27,37 @@
 import org.apache.activemq.util.ByteArrayInputStream;
 import org.apache.activemq.util.ByteArrayOutputStream;
 import org.apache.activemq.util.ByteSequence;
+import org.apache.activemq.util.FactoryFinder;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
 
 public class MultiWireFormatFactory implements WireFormatFactory{
+    
+    private static final Log LOG = LogFactory.getLog(MultiWireFormatFactory.class);
+    
+    private static final FactoryFinder WIREFORMAT_FACTORY_FINDER = new FactoryFinder("META-INF/services/org/apache/activemq/wireformat/");
+
+    private String wireFormats="openwire,stomp";
+    private ArrayList<DiscriminatableWireFormatFactory> wireFormatFactories;
+    
+    static public class WireFormatConnected {
+        final private DiscriminatableWireFormatFactory wireFormatFactory;
+        final private WireFormat wireFormat;
+        
+        public WireFormatConnected(DiscriminatableWireFormatFactory wireFormatFactory, WireFormat wireFormat) {
+            this.wireFormatFactory = wireFormatFactory;
+            this.wireFormat = wireFormat;
+        }
+
+        public DiscriminatableWireFormatFactory getWireFormatFactory() {
+            return wireFormatFactory;
+        }
 
+        public WireFormat getWireFormat() {
+            return wireFormat;
+        }
+    }
+    
     static class MultiWireFormat implements WireFormat {
 
         ArrayList<DiscriminatableWireFormatFactory> wireFormatFactories = new ArrayList<DiscriminatableWireFormatFactory>();
@@ -64,7 +92,7 @@
                     if( wff.matchesWireformatHeader(baos.toByteSequence()) ) {
                         wireFormat = wff.createWireFormat();
                         peeked = new ByteArrayInputStream(baos.toByteSequence());
-                        return wireFormat;
+                        return new WireFormatConnected(wff, wireFormat);
                     }
                 }
                 
@@ -112,11 +140,28 @@
         
     public WireFormat createWireFormat() {
         MultiWireFormat rc = new MultiWireFormat();
-        ArrayList<DiscriminatableWireFormatFactory> wireFormatFactories = new ArrayList<DiscriminatableWireFormatFactory>();
-        wireFormatFactories.add(new DiscriminatableStompWireFormatFactory());
-        wireFormatFactories.add(new DiscriminatableOpenWireFormatFactory());
+        if( wireFormatFactories == null ) {
+            wireFormatFactories = new ArrayList<DiscriminatableWireFormatFactory>();
+            String[] formats = getWireFormats().split("\\,");
+            for (int i = 0; i < formats.length; i++) {
+                try {
+                    wireFormatFactories.add((DiscriminatableWireFormatFactory)WIREFORMAT_FACTORY_FINDER.newInstance(formats[i]));
+                } catch (Exception e) {
+                    LOG.warn("Invalid wireformat '"+formats[i]+"': "+e.getMessage());
+                }
+            }
+        }
         rc.setWireFormatFactories(wireFormatFactories);
         return rc;
     }
 
+    public String getWireFormats() {
+        return wireFormats;
+    }
+
+    public void setWireFormats(String formats) {
+        this.wireFormats = formats;
+    }
+
+
 }

Added: activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/openwire
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/openwire?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/openwire (added)
+++ activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/openwire Wed Mar 18 15:00:22 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.broker.openwire.OpenwireProtocolHandler

Added: activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/stomp
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/stomp?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/stomp (added)
+++ activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/broker/protocol/stomp Wed Mar 18 15:00:22 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.broker.stomp.StompProtocolHandler
\ No newline at end of file

Added: activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/default
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/default?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/default (added)
+++ activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/default Wed Mar 18 15:00:22 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.wireformat.DiscriminatableOpenWireFormatFactory

Added: activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/multi
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/multi?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/multi (added)
+++ activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/multi Wed Mar 18 15:00:22 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.wireformat.MultiWireFormatFactory

Added: activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/openwire
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/openwire?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/openwire (added)
+++ activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/openwire Wed Mar 18 15:00:22 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.wireformat.DiscriminatableOpenWireFormatFactory

Added: activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/stomp
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/stomp?rev=755611&view=auto
==============================================================================
--- activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/stomp (added)
+++ activemq/sandbox/activemq-flow/src/main/resources/META-INF/services/org/apache/activemq/wireformat/stomp Wed Mar 18 15:00:22 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.wireformat.DiscriminatableStompWireFormatFactory
\ No newline at end of file