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 2006/10/16 20:48:05 UTC

svn commit: r464620 [4/6] - in /incubator/activemq/sandbox/qpid: src/main/java/org/apache/activemq/qpid/command/ src/main/java/org/apache/activemq/qpid/transport/ src/main/java/org/apache/activemq/qpid/wireformat/ src/main/java/org/apache/activemq/qpid...

Added: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/command/Visitor.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/command/Visitor.java?view=auto&rev=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/command/Visitor.java (added)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/command/Visitor.java Mon Oct 16 11:47:51 2006
@@ -0,0 +1,282 @@
+package org.apache.activemq.qpid.command;
+
+public class Visitor {
+
+	public Object processAccessRequestBody(AccessRequestBody body) throws Exception {
+		return null;
+	}
+	public Object processAccessRequestOkBody(AccessRequestOkBody body) throws Exception {
+		return null;
+	}
+	public Object processQueueBindOkBody(QueueBindOkBody body) throws Exception {
+		return null;
+	}
+	public Object processQueuePurgeBody(QueuePurgeBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamConsumeOkBody(StreamConsumeOkBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamQosBody(StreamQosBody body) throws Exception {
+		return null;
+	}
+	public Object processTestContentOkBody(TestContentOkBody body) throws Exception {
+		return null;
+	}
+	public Object processTestTableBody(TestTableBody body) throws Exception {
+		return null;
+	}
+	public Object processTestTableOkBody(TestTableOkBody body) throws Exception {
+		return null;
+	}
+	public Object processTxRollbackOkBody(TxRollbackOkBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamCancelBody(StreamCancelBody body) throws Exception {
+		return null;
+	}
+	public Object processQueuePurgeOkBody(QueuePurgeOkBody body) throws Exception {
+		return null;
+	}
+	public Object processQueueDeleteBody(QueueDeleteBody body) throws Exception {
+		return null;
+	}
+	public Object processQueueDeclareBody(QueueDeclareBody body) throws Exception {
+		return null;
+	}
+	public Object processQueueBindBody(QueueBindBody body) throws Exception {
+		return null;
+	}
+	public Object processTxCommitBody(TxCommitBody body) throws Exception {
+		return null;
+	}
+	public Object processTxCommitOkBody(TxCommitOkBody body) throws Exception {
+		return null;
+	}
+	public Object processTxRollbackBody(TxRollbackBody body) throws Exception {
+		return null;
+	}
+	public Object processTxSelectBody(TxSelectBody body) throws Exception {
+		return null;
+	}
+	public Object processTxSelectOkBody(TxSelectOkBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicAckBody(BasicAckBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicCancelBody(BasicCancelBody body) throws Exception {
+		return null;
+	}
+	public Object processFileStageBody(FileStageBody body) throws Exception {
+		return null;
+	}
+	public Object processFileReturnBody(FileReturnBody body) throws Exception {
+		return null;
+	}
+	public Object processFileQosOkBody(FileQosOkBody body) throws Exception {
+		return null;
+	}
+	public Object processTestIntegerOkBody(TestIntegerOkBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamPublishBody(StreamPublishBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamDeliverBody(StreamDeliverBody body) throws Exception {
+		return null;
+	}
+	public Object processQueueDeleteOkBody(QueueDeleteOkBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamQosOkBody(StreamQosOkBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamCancelOkBody(StreamCancelOkBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamConsumeBody(StreamConsumeBody body) throws Exception {
+		return null;
+	}
+	public Object processQueueDeclareOkBody(QueueDeclareOkBody body) throws Exception {
+		return null;
+	}
+	public Object processFileRejectBody(FileRejectBody body) throws Exception {
+		return null;
+	}
+	public Object processFileQosBody(FileQosBody body) throws Exception {
+		return null;
+	}
+	public Object processFilePublishBody(FilePublishBody body) throws Exception {
+		return null;
+	}
+	public Object processTunnelRequestBody(TunnelRequestBody body) throws Exception {
+		return null;
+	}
+	public Object processTestStringOkBody(TestStringOkBody body) throws Exception {
+		return null;
+	}
+	public Object processTestStringBody(TestStringBody body) throws Exception {
+		return null;
+	}
+	public Object processTestIntegerBody(TestIntegerBody body) throws Exception {
+		return null;
+	}
+	public Object processTestContentBody(TestContentBody body) throws Exception {
+		return null;
+	}
+	public Object processStreamReturnBody(StreamReturnBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicCancelOkBody(BasicCancelOkBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicDeliverBody(BasicDeliverBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicConsumeOkBody(BasicConsumeOkBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicConsumeBody(BasicConsumeBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicGetBody(BasicGetBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelOpenBody(ChannelOpenBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicGetEmptyBody(BasicGetEmptyBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicGetOkBody(BasicGetOkBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicPublishBody(BasicPublishBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicQosBody(BasicQosBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicQosOkBody(BasicQosOkBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicRecoverBody(BasicRecoverBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicRejectBody(BasicRejectBody body) throws Exception {
+		return null;
+	}
+	public Object processBasicReturnBody(BasicReturnBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelAlertBody(ChannelAlertBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelCloseBody(ChannelCloseBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelCloseOkBody(ChannelCloseOkBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelFlowBody(ChannelFlowBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelFlowOkBody(ChannelFlowOkBody body) throws Exception {
+		return null;
+	}
+	public Object processChannelOpenOkBody(ChannelOpenOkBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionCloseBody(ConnectionCloseBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionCloseOkBody(ConnectionCloseOkBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionOpenBody(ConnectionOpenBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionOpenOkBody(ConnectionOpenOkBody body) throws Exception {
+		return null;
+	}
+	public Object processFileAckBody(FileAckBody body) throws Exception {
+		return null;
+	}
+	public Object processFileCancelBody(FileCancelBody body) throws Exception {
+		return null;
+	}
+	public Object processFileCancelOkBody(FileCancelOkBody body) throws Exception {
+		return null;
+	}
+	public Object processFileConsumeBody(FileConsumeBody body) throws Exception {
+		return null;
+	}
+	public Object processFileConsumeOkBody(FileConsumeOkBody body) throws Exception {
+		return null;
+	}
+	public Object processFileDeliverBody(FileDeliverBody body) throws Exception {
+		return null;
+	}
+	public Object processFileOpenOkBody(FileOpenOkBody body) throws Exception {
+		return null;
+	}
+	public Object processFileOpenBody(FileOpenBody body) throws Exception {
+		return null;
+	}
+	public Object processDtxSelectBody(DtxSelectBody body) throws Exception {
+		return null;
+	}
+	public Object processDtxSelectOkBody(DtxSelectOkBody body) throws Exception {
+		return null;
+	}
+	public Object processDtxStartBody(DtxStartBody body) throws Exception {
+		return null;
+	}
+	public Object processDtxStartOkBody(DtxStartOkBody body) throws Exception {
+		return null;
+	}
+	public Object processExchangeDeclareBody(ExchangeDeclareBody body) throws Exception {
+		return null;
+	}
+	public Object processExchangeDeclareOkBody(ExchangeDeclareOkBody body) throws Exception {
+		return null;
+	}
+	public Object processExchangeDeleteBody(ExchangeDeleteBody body) throws Exception {
+		return null;
+	}
+	public Object processExchangeDeleteOkBody(ExchangeDeleteOkBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionRedirectBody(ConnectionRedirectBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionSecureBody(ConnectionSecureBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionSecureOkBody(ConnectionSecureOkBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionStartBody(ConnectionStartBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionStartOkBody(ConnectionStartOkBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionTuneBody(ConnectionTuneBody body) throws Exception {
+		return null;
+	}
+	public Object processConnectionTuneOkBody(ConnectionTuneOkBody body) throws Exception {
+		return null;
+	}
+	public Object processHeartbeatBody(HeartbeatBody body) throws Exception {
+		return null;
+	}
+	public Object processContentHeaderBody(ContentHeaderBody body) throws Exception {
+		return null;
+	}
+	public Object processContentBody(ContentBody body) throws Exception {
+		return null;
+	}
+	
+}

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/Proxy.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/Proxy.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/Proxy.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/Proxy.java Mon Oct 16 11:47:51 2006
@@ -41,7 +41,7 @@
 	public static void main(String[] args) throws Exception {
 				
 		String bind = "qpid://localhost:5673";
-		String proxy = "qpid://localhost:5672";
+		String proxy = "qpid://localhost:5672?trace=true";
 		if( args.length > 0 ) {
 			bind = args[0];
 		}

Added: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidServerTransportFilter.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidServerTransportFilter.java?view=auto&rev=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidServerTransportFilter.java (added)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidServerTransportFilter.java Mon Oct 16 11:47:51 2006
@@ -0,0 +1,51 @@
+/**
+ *
+ * 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.qpid.transport;
+
+import org.apache.activemq.qpid.command.AccessRequestBody;
+import org.apache.activemq.qpid.command.Frame;
+import org.apache.activemq.qpid.command.Visitor;
+import org.apache.activemq.transport.Transport;
+import org.apache.activemq.transport.TransportFilter;
+
+/**
+ * This filter should eventually translate the qpid command set to the ActiveMQ command set.
+ *  
+ * @author chirino
+ */
+public class QpidServerTransportFilter extends TransportFilter {
+
+	public QpidServerTransportFilter(Transport next) {
+		super(next);
+	}
+
+	public void onCommand(Object command) {
+		Frame frame = (Frame) command;
+		try {
+			frame.process(new Visitor() {
+				public Object processAccessRequestBody(AccessRequestBody body) throws Exception {
+					// TODO Auto-generated method stub
+					return super.processAccessRequestBody(body);
+				}
+			});
+		} catch (Exception e) {
+		}
+		super.onCommand(command);
+	}
+	
+}

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidTransportFactory.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidTransportFactory.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidTransportFactory.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/transport/QpidTransportFactory.java Mon Oct 16 11:47:51 2006
@@ -20,6 +20,7 @@
 import java.io.IOException;
 import java.net.URI;
 import java.net.UnknownHostException;
+import java.util.HashMap;
 import java.util.Map;
 
 import javax.net.SocketFactory;
@@ -44,20 +45,25 @@
 
     
     public Transport configure(Transport transport, WireFormat wf, Map options) throws Exception {
+    	((QpidWireFormat)wf).setSendProtocolInitiation(true);
+    	((QpidWireFormat)wf).setWaitForProtocolInitiation(false);    	
     	transport = compositeConfigure(transport, wf, options);
         transport = new MutexTransport(transport);
         // transport = new ResponseCorrelator(transport);
         return transport;
     }
+    
+    public Transport serverConfigure(Transport transport, WireFormat wf, HashMap options) throws Exception {
+    	((QpidWireFormat)wf).setSendProtocolInitiation(false);
+    	((QpidWireFormat)wf).setWaitForProtocolInitiation(true);    	
+    	transport = compositeConfigure(transport, wf, options);    	
+    	transport = new QpidServerTransportFilter(transport);
+        transport = new MutexTransport(transport);
+        return transport;
+    }
 
     protected TcpTransport createTcpTransport(WireFormat wf, SocketFactory socketFactory, URI location, URI localLocation) throws UnknownHostException, IOException {
-    	((QpidWireFormat)wf).setSendProtocolInitiation(true);
-    	((QpidWireFormat)wf).setWaitForProtocolInitiation(false);    	
     	return super.createTcpTransport(wf, socketFactory, location, localLocation);
     }
 
-    public Transport compositeConfigure(Transport transport, WireFormat format, Map options) {
-//    	transport = new StompTransportFilter(transport, new LegacyFrameTranslator());
-    	return super.compositeConfigure(transport, format, options);
-    }
 }

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/QpidWireFormat.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/QpidWireFormat.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/QpidWireFormat.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/QpidWireFormat.java Mon Oct 16 11:47:51 2006
@@ -169,7 +169,7 @@
 		}
 		
 		Frame frame = (Frame) object;
-    	byte type = frame.getType();    	
+    	byte type = frame.getFrameType();    	
         buffer.writeByte(type);
         EncodingUtils.writeUnsignedShort(buffer, frame.channel);
         

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/AccessRequestOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicAckBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicAckBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicAckBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicAckBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicCancelOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicConsumeOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicDeliverBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicDeliverBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicDeliverBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicDeliverBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetEmptyBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetEmptyBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetEmptyBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetEmptyBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicGetOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicPublishBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicPublishBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicPublishBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicPublishBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicQosOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRecoverBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRecoverBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRecoverBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRecoverBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRejectBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRejectBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRejectBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicRejectBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicReturnBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicReturnBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicReturnBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/BasicReturnBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelAlertBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelAlertBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelAlertBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelAlertBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelCloseOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelFlowOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ChannelOpenOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionCloseOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionOpenOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionRedirectBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionRedirectBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionRedirectBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionRedirectBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionSecureOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionStartOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneOkBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneOkBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneOkBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/ConnectionTuneOkBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;
 

Modified: incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/DtxSelectBodyMarshaller.java
URL: http://svn.apache.org/viewvc/incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/DtxSelectBodyMarshaller.java?view=diff&rev=464620&r1=464619&r2=464620
==============================================================================
--- incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/DtxSelectBodyMarshaller.java (original)
+++ incubator/activemq/sandbox/qpid/src/main/java/org/apache/activemq/qpid/wireformat/v8_0/DtxSelectBodyMarshaller.java Mon Oct 16 11:47:51 2006
@@ -1,20 +1,20 @@
 /**
-*
-* Copyright (c) 2006 The Apache Software Foundation
-*
-* Licensed 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.
-*
-*/
+ *
+ * Copyright (c) 2006 The Apache Software Foundation
+ *
+ * Licensed 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.qpid.wireformat.v8_0;