You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by rg...@apache.org on 2011/08/14 19:15:08 UTC

svn commit: r1157566 [13/23] - in /qpid: branches/rg-amqp-1-0-sandbox/qpid/java/ branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-client/ branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-client/src/ branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-client/...

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/WrapperType.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/WrapperType.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/WrapperType.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/WrapperType.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,27 @@
+/*
+*
+* 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.qpid.amqp_1_0.type;
+
+public interface WrapperType
+{
+    Object getValue();
+}

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/codec/AMQPDescribedTypeRegistry.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/codec/AMQPDescribedTypeRegistry.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/codec/AMQPDescribedTypeRegistry.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/codec/AMQPDescribedTypeRegistry.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,378 @@
+
+
+package org.apache.qpid.amqp_1_0.type.codec;
+
+import org.apache.qpid.amqp_1_0.codec.BinaryWriter;
+import org.apache.qpid.amqp_1_0.codec.BooleanWriter;
+import org.apache.qpid.amqp_1_0.codec.ByteWriter;
+import org.apache.qpid.amqp_1_0.codec.CharWriter;
+import org.apache.qpid.amqp_1_0.codec.DescribedTypeConstructor;
+import org.apache.qpid.amqp_1_0.codec.DescribedTypeConstructorRegistry;
+import org.apache.qpid.amqp_1_0.codec.DoubleWriter;
+import org.apache.qpid.amqp_1_0.codec.FloatWriter;
+import org.apache.qpid.amqp_1_0.codec.IntegerWriter;
+import org.apache.qpid.amqp_1_0.codec.ListWriter;
+import org.apache.qpid.amqp_1_0.codec.LongWriter;
+import org.apache.qpid.amqp_1_0.codec.MapWriter;
+import org.apache.qpid.amqp_1_0.codec.NullWriter;
+import org.apache.qpid.amqp_1_0.codec.RestrictedTypeValueWriter;
+import org.apache.qpid.amqp_1_0.codec.ShortWriter;
+import org.apache.qpid.amqp_1_0.codec.StringWriter;
+import org.apache.qpid.amqp_1_0.codec.SymbolWriter;
+import org.apache.qpid.amqp_1_0.codec.SymbolArrayWriter;
+import org.apache.qpid.amqp_1_0.codec.TimestampWriter;
+import org.apache.qpid.amqp_1_0.codec.TypeConstructor;
+import org.apache.qpid.amqp_1_0.codec.UUIDWriter;
+import org.apache.qpid.amqp_1_0.codec.UnsignedByteWriter;
+import org.apache.qpid.amqp_1_0.codec.UnsignedIntegerWriter;
+import org.apache.qpid.amqp_1_0.codec.UnsignedLongWriter;
+import org.apache.qpid.amqp_1_0.codec.UnsignedShortWriter;
+import org.apache.qpid.amqp_1_0.codec.ValueWriter;
+
+
+import org.apache.qpid.amqp_1_0.type.RestrictedType;
+import org.apache.qpid.amqp_1_0.type.transport.*;
+import org.apache.qpid.amqp_1_0.type.transport.codec.*;
+
+import org.apache.qpid.amqp_1_0.type.messaging.*;
+import org.apache.qpid.amqp_1_0.type.messaging.codec.*;
+
+import org.apache.qpid.amqp_1_0.type.transaction.*;
+import org.apache.qpid.amqp_1_0.type.transaction.codec.*;
+
+import org.apache.qpid.amqp_1_0.type.security.*;
+import org.apache.qpid.amqp_1_0.type.security.codec.*;
+
+import java.lang.reflect.Array;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+
+public class AMQPDescribedTypeRegistry implements DescribedTypeConstructorRegistry, ValueWriter.Registry
+{
+
+    private final Map<Object, DescribedTypeConstructor> _constructorRegistry = new HashMap<Object, DescribedTypeConstructor>();
+
+    public void register(Object descriptor, DescribedTypeConstructor constructor)
+    {
+        _constructorRegistry.put(descriptor, constructor);
+    }
+
+    public void register(Object descriptor, DescribedTypeConstructor constructor, TypeConstructor describedConstructor)
+    {
+        _constructorRegistry.put(descriptor, constructor);
+    }
+
+    public DescribedTypeConstructor getConstructor(Object descriptor)
+    {
+        return _constructorRegistry.get(descriptor);
+    }
+
+    private AMQPDescribedTypeRegistry()
+    {
+    }
+
+    public AMQPDescribedTypeRegistry registerTransportLayer()
+    {
+        registerTransportConstructors(this);
+        registerTransportWriters(this);
+        return this;
+    }
+
+    public AMQPDescribedTypeRegistry registerMessagingLayer()
+    {
+        registerMessagingConstructors(this);
+        registerMessagingWriters(this);
+        return this;
+    }
+
+    public AMQPDescribedTypeRegistry registerTransactionLayer()
+    {
+        registerTransactionsConstructors(this);
+        registerTransactionsWriters(this);
+        return this;
+    }
+
+    public AMQPDescribedTypeRegistry registerSecurityLayer()
+    {
+        registerSecurityConstructors(this);
+        registerSecurityWriters(this);
+        return this;
+    }
+
+    public static AMQPDescribedTypeRegistry newInstance()
+    {
+        AMQPDescribedTypeRegistry registry = new AMQPDescribedTypeRegistry();
+
+        NullWriter.register(registry);
+        BooleanWriter.register(registry);
+        ByteWriter.register(registry);
+        UnsignedByteWriter.register(registry);
+        ShortWriter.register(registry);
+        UnsignedShortWriter.register(registry);
+        IntegerWriter.register(registry);
+        UnsignedIntegerWriter.register(registry);
+        CharWriter.register(registry);
+        FloatWriter.register(registry);
+        LongWriter.register(registry);
+        UnsignedLongWriter.register(registry);
+        DoubleWriter.register(registry);
+        TimestampWriter.register(registry);
+        UUIDWriter.register(registry);
+        StringWriter.register(registry);
+        SymbolWriter.register(registry);
+        BinaryWriter.register(registry);
+        ListWriter.register(registry);
+        MapWriter.register(registry);
+
+        SymbolArrayWriter.register(registry);
+
+        return registry;
+    }
+
+
+        
+    private static void registerTransportWriters(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        OpenWriter.register(registry);
+        BeginWriter.register(registry);
+        AttachWriter.register(registry);
+        FlowWriter.register(registry);
+        TransferWriter.register(registry);
+        DispositionWriter.register(registry);
+        DetachWriter.register(registry);
+        EndWriter.register(registry);
+        CloseWriter.register(registry);
+        RestrictedTypeValueWriter.register(registry,Role.class);
+        RestrictedTypeValueWriter.register(registry,SenderSettleMode.class);
+        RestrictedTypeValueWriter.register(registry,ReceiverSettleMode.class);
+        ErrorWriter.register(registry);
+        RestrictedTypeValueWriter.register(registry,AmqpError.class);
+        RestrictedTypeValueWriter.register(registry,ConnectionError.class);
+        RestrictedTypeValueWriter.register(registry,SessionError.class);
+        RestrictedTypeValueWriter.register(registry,LinkError.class);
+    }
+
+    private static void registerMessagingWriters(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        HeaderWriter.register(registry);
+        DeliveryAnnotationsWriter.register(registry);
+        MessageAnnotationsWriter.register(registry);
+        PropertiesWriter.register(registry);
+        ApplicationPropertiesWriter.register(registry);
+        DataWriter.register(registry);
+        AmqpSequenceWriter.register(registry);
+        AmqpValueWriter.register(registry);
+        FooterWriter.register(registry);
+        ReceivedWriter.register(registry);
+        AcceptedWriter.register(registry);
+        RejectedWriter.register(registry);
+        ReleasedWriter.register(registry);
+        ModifiedWriter.register(registry);
+        SourceWriter.register(registry);
+        TargetWriter.register(registry);
+        RestrictedTypeValueWriter.register(registry,TerminusDurability.class);
+        RestrictedTypeValueWriter.register(registry,TerminusExpiryPolicy.class);
+        RestrictedTypeValueWriter.register(registry,StdDistMode.class);
+        DeleteOnCloseWriter.register(registry);
+        DeleteOnNoLinksWriter.register(registry);
+        DeleteOnNoMessagesWriter.register(registry);
+        DeleteOnNoLinksOrMessagesWriter.register(registry);
+    }
+
+    private static void registerTransactionsWriters(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        CoordinatorWriter.register(registry);
+        DeclareWriter.register(registry);
+        DischargeWriter.register(registry);
+        DeclaredWriter.register(registry);
+        TransactionalStateWriter.register(registry);
+        RestrictedTypeValueWriter.register(registry,TxnCapability.class);
+        RestrictedTypeValueWriter.register(registry,TransactionErrors.class);
+    }
+
+    private static void registerSecurityWriters(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        SaslMechanismsWriter.register(registry);
+        SaslInitWriter.register(registry);
+        SaslChallengeWriter.register(registry);
+        SaslResponseWriter.register(registry);
+        SaslOutcomeWriter.register(registry);
+        RestrictedTypeValueWriter.register(registry,SaslCode.class);
+    }
+
+    private static void registerTransportConstructors(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        OpenConstructor.register(registry);
+        BeginConstructor.register(registry);
+        AttachConstructor.register(registry);
+        FlowConstructor.register(registry);
+        TransferConstructor.register(registry);
+        DispositionConstructor.register(registry);
+        DetachConstructor.register(registry);
+        EndConstructor.register(registry);
+        CloseConstructor.register(registry);
+        ErrorConstructor.register(registry);
+    }
+
+    private static void registerMessagingConstructors(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        HeaderConstructor.register(registry);
+        DeliveryAnnotationsConstructor.register(registry);
+        MessageAnnotationsConstructor.register(registry);
+        PropertiesConstructor.register(registry);
+        ApplicationPropertiesConstructor.register(registry);
+        DataConstructor.register(registry);
+        AmqpSequenceConstructor.register(registry);
+        AmqpValueConstructor.register(registry);
+        FooterConstructor.register(registry);
+        ReceivedConstructor.register(registry);
+        AcceptedConstructor.register(registry);
+        RejectedConstructor.register(registry);
+        ReleasedConstructor.register(registry);
+        ModifiedConstructor.register(registry);
+        SourceConstructor.register(registry);
+        TargetConstructor.register(registry);
+        DeleteOnCloseConstructor.register(registry);
+        DeleteOnNoLinksConstructor.register(registry);
+        DeleteOnNoMessagesConstructor.register(registry);
+        DeleteOnNoLinksOrMessagesConstructor.register(registry);
+    }
+
+    private static void registerTransactionsConstructors(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        CoordinatorConstructor.register(registry);
+        DeclareConstructor.register(registry);
+        DischargeConstructor.register(registry);
+        DeclaredConstructor.register(registry);
+        TransactionalStateConstructor.register(registry);
+    }
+
+    private static void registerSecurityConstructors(final AMQPDescribedTypeRegistry registry)
+    {
+    
+        SaslMechanismsConstructor.register(registry);
+        SaslInitConstructor.register(registry);
+        SaslChallengeConstructor.register(registry);
+        SaslResponseConstructor.register(registry);
+        SaslOutcomeConstructor.register(registry);
+    }
+
+
+    private final Map<Class, ValueWriter.Factory> _writerMap = new HashMap<Class, ValueWriter.Factory>();
+    private final Map<Class, ValueWriter> _cachedWriters = new HashMap<Class,ValueWriter>();
+
+    public <V extends Object> ValueWriter<V> getValueWriter(V value, Map<Class, ValueWriter> localCache)
+    {
+        Class<? extends Object> clazz = value == null ? Void.TYPE : value.getClass();
+        ValueWriter writer = null; // TODO localCache.get(clazz);
+        if(writer == null || !writer.isComplete())
+        {
+            writer = getValueWriter(value);
+            localCache.put(clazz, writer);
+        }
+        else
+        {
+            writer.setValue(value);
+        }
+
+
+        return writer;
+    }
+
+
+    public <V extends Object> ValueWriter<V> getValueWriter(V value)
+    {
+
+        Class<? extends Object> clazz = value == null ? Void.TYPE : value.getClass();
+
+        ValueWriter writer = null; // TODO _cachedWriters.get(clazz);
+        if(writer == null || !writer.isComplete())
+        {
+            ValueWriter.Factory<V> factory = (ValueWriter.Factory<V>) (_writerMap.get(clazz));
+
+            if(factory == null)
+            {
+                if(value instanceof List)
+                {
+                    factory = _writerMap.get(List.class);
+                    _writerMap.put(value.getClass(), factory);
+                    writer = factory.newInstance(this);
+                    if(writer.isCacheable())
+                    {
+                        _cachedWriters.put(clazz, writer);
+                    }
+                    writer.setValue(value);
+
+                }
+                else if(value instanceof Map)
+                {
+                    factory = _writerMap.get(Map.class);
+                    _writerMap.put(value.getClass(), factory);
+                    writer = factory.newInstance(this);
+                    if(writer.isCacheable())
+                    {
+                        _cachedWriters.put(clazz, writer);
+                    }
+                    writer.setValue(value);
+
+                }
+                else if(value.getClass().isArray())
+                {
+                    if(RestrictedType.class.isAssignableFrom(value.getClass().getComponentType()))
+                    {
+                        RestrictedType[] restrictedTypes = (RestrictedType[]) value;
+                        Object[] newVals = (Object[]) Array.newInstance(restrictedTypes[0].getValue().getClass(),
+                                                                        restrictedTypes.length);
+                        for(int i = 0; i < restrictedTypes.length; i++)
+                        {
+                            newVals[i] = restrictedTypes[i].getValue();
+                        }
+                        return (ValueWriter<V>) getValueWriter(newVals);
+                    }
+                    // TODO primitive array types
+                    factory = _writerMap.get(List.class);
+                    writer = factory.newInstance(this);
+                    writer.setValue(Arrays.asList((Object[])value));
+
+                }
+                else
+                {
+                    return null;
+                }
+            }
+            else
+            {
+                writer = factory.newInstance(this);
+                if(writer.isCacheable())
+                {
+                    _cachedWriters.put(clazz, writer);
+                }
+                writer.setValue(value);
+            }
+        }
+        else
+        {
+            writer.setValue(value);
+        }
+
+        return writer;
+
+    }
+
+    public <V extends Object> ValueWriter<V> register(Class<V> clazz, ValueWriter.Factory<V> writer)
+    {
+        return (ValueWriter<V>) _writerMap.put(clazz, writer);
+    }
+
+}
+
+    
\ No newline at end of file

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Accepted.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Accepted.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Accepted.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Accepted.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,46 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Accepted
+  implements org.apache.qpid.amqp_1_0.type.DeliveryState, Outcome
+  {
+
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Accepted{");
+        final int origLength = builder.length();
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpSequence.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpSequence.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpSequence.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpSequence.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,70 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import java.util.List;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class AmqpSequence
+  implements Section
+  {
+
+
+
+    private final List _value;
+
+    public AmqpSequence(List value)
+    {
+        _value = value;
+    }
+
+    public List getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+      @Override
+      public String toString()
+      {
+          return "AmqpSequence{" +
+                   _value +
+                  '}';
+      }
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpValue.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpValue.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpValue.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/AmqpValue.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,66 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class AmqpValue
+  implements Section
+  {
+
+
+
+    private final Object _value;
+
+    public AmqpValue(Object value)
+    {
+        _value = value;
+    }
+
+    public Object getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+      @Override
+      public String toString()
+      {
+          return "AmqpValue{(" + _value.getClass().getName() + ')' + _value + '}';
+      }
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/ApplicationProperties.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/ApplicationProperties.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/ApplicationProperties.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/ApplicationProperties.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,64 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class ApplicationProperties
+  implements Section
+  {
+
+
+
+    private final Map _value;
+
+    public ApplicationProperties(Map value)
+    {
+        _value = value;
+    }
+
+    public Map getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Data.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Data.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Data.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Data.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,68 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Data
+  implements Section
+  {
+
+
+
+    private final Binary _value;
+
+    public Data(Binary value)
+    {
+        _value = value;
+    }
+
+    public Binary getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+      @Override
+      public String toString()
+      {
+          return "Data{" +
+                 _value +
+                 '}';
+      }
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnClose.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnClose.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnClose.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnClose.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,46 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class DeleteOnClose
+  implements LifetimePolicy
+  {
+
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("DeleteOnClose{");
+        final int origLength = builder.length();
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinks.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinks.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinks.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinks.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,46 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class DeleteOnNoLinks
+  implements LifetimePolicy
+  {
+
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("DeleteOnNoLinks{");
+        final int origLength = builder.length();
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinksOrMessages.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinksOrMessages.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinksOrMessages.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoLinksOrMessages.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,46 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class DeleteOnNoLinksOrMessages
+  implements LifetimePolicy
+  {
+
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("DeleteOnNoLinksOrMessages{");
+        final int origLength = builder.length();
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoMessages.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoMessages.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoMessages.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeleteOnNoMessages.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,46 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class DeleteOnNoMessages
+  implements LifetimePolicy
+  {
+
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("DeleteOnNoMessages{");
+        final int origLength = builder.length();
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryAnnotations.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryAnnotations.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryAnnotations.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryAnnotations.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,64 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class DeliveryAnnotations
+  implements Section
+  {
+
+
+
+    private final Map _value;
+
+    public DeliveryAnnotations(Map value)
+    {
+        _value = value;
+    }
+
+    public Map getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryState.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryState.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryState.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/DeliveryState.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,154 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class DeliveryState
+  implements org.apache.qpid.amqp_1_0.type.DeliveryState
+  {
+
+
+    private Map _options;
+
+    private UnsignedInteger _sectionNumber;
+
+    private UnsignedLong _sectionOffset;
+
+    private Outcome _outcome;
+
+    private Binary _txnId;
+
+    public Map getOptions()
+    {
+        return _options;
+    }
+
+    public void setOptions(Map options)
+    {
+        _options = options;
+    }
+
+    public UnsignedInteger getSectionNumber()
+    {
+        return _sectionNumber;
+    }
+
+    public void setSectionNumber(UnsignedInteger sectionNumber)
+    {
+        _sectionNumber = sectionNumber;
+    }
+
+    public UnsignedLong getSectionOffset()
+    {
+        return _sectionOffset;
+    }
+
+    public void setSectionOffset(UnsignedLong sectionOffset)
+    {
+        _sectionOffset = sectionOffset;
+    }
+
+    public Outcome getOutcome()
+    {
+        return _outcome;
+    }
+
+    public void setOutcome(Outcome outcome)
+    {
+        _outcome = outcome;
+    }
+
+    public Binary getTxnId()
+    {
+        return _txnId;
+    }
+
+    public void setTxnId(Binary txnId)
+    {
+        _txnId = txnId;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("DeliveryState{");
+        final int origLength = builder.length();
+
+        if(_options != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("options=").append(_options);
+        }
+
+        if(_sectionNumber != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("sectionNumber=").append(_sectionNumber);
+        }
+
+        if(_sectionOffset != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("sectionOffset=").append(_sectionOffset);
+        }
+
+        if(_outcome != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("outcome=").append(_outcome);
+        }
+
+        if(_txnId != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("txnId=").append(_txnId);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Filter.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Filter.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Filter.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Filter.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,87 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Filter
+  {
+
+
+    private Symbol _type;
+
+    private Predicate _predicate;
+
+    public Symbol getType()
+    {
+        return _type;
+    }
+
+    public void setType(Symbol type)
+    {
+        _type = type;
+    }
+
+    public Predicate getPredicate()
+    {
+        return _predicate;
+    }
+
+    public void setPredicate(Predicate predicate)
+    {
+        _predicate = predicate;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Filter{");
+        final int origLength = builder.length();
+
+        if(_type != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("type=").append(_type);
+        }
+
+        if(_predicate != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("predicate=").append(_predicate);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Footer.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Footer.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Footer.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Footer.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,70 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Footer
+  implements Section
+  {
+
+
+
+    private final Map _value;
+
+    public Footer(Map value)
+    {
+        _value = value;
+    }
+
+    public Map getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+      @Override
+      public String toString()
+      {
+          return "Footer{" + _value +
+                  '}';
+      }
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Header.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Header.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Header.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Header.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,161 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Header
+  implements Section
+  {
+
+
+    private Boolean _durable;
+
+    private UnsignedByte _priority;
+
+    private UnsignedInteger _ttl;
+
+    private Boolean _firstAcquirer;
+
+    private UnsignedInteger _deliveryCount;
+
+    public Boolean getDurable()
+    {
+        return _durable;
+    }
+
+    public void setDurable(Boolean durable)
+    {
+        _durable = durable;
+    }
+
+    public UnsignedByte getPriority()
+    {
+        return _priority;
+    }
+
+    public void setPriority(UnsignedByte priority)
+    {
+        _priority = priority;
+    }
+
+    public UnsignedInteger getTtl()
+    {
+        return _ttl;
+    }
+
+    public void setTtl(UnsignedInteger ttl)
+    {
+        _ttl = ttl;
+    }
+
+    public Boolean getFirstAcquirer()
+    {
+        return _firstAcquirer;
+    }
+
+    public void setFirstAcquirer(Boolean firstAcquirer)
+    {
+        _firstAcquirer = firstAcquirer;
+    }
+
+    public UnsignedInteger getDeliveryCount()
+    {
+        return _deliveryCount;
+    }
+
+    public void setDeliveryCount(UnsignedInteger deliveryCount)
+    {
+        _deliveryCount = deliveryCount;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Header{");
+        final int origLength = builder.length();
+
+        if(_durable != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("durable=").append(_durable);
+        }
+
+        if(_priority != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("priority=").append(_priority);
+        }
+
+        if(_ttl != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("ttl=").append(_ttl);
+        }
+
+        if(_firstAcquirer != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("firstAcquirer=").append(_firstAcquirer);
+        }
+
+        if(_deliveryCount != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("deliveryCount=").append(_deliveryCount);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/MessageAnnotations.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/MessageAnnotations.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/MessageAnnotations.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/MessageAnnotations.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,64 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class MessageAnnotations
+  implements Section
+  {
+
+
+
+    private final Map _value;
+
+    public MessageAnnotations(Map value)
+    {
+        _value = value;
+    }
+
+    public Map getValue()
+    {
+        return _value;
+    }
+
+
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Modified.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Modified.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Modified.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Modified.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,112 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Modified
+  implements org.apache.qpid.amqp_1_0.type.DeliveryState, Outcome
+  {
+
+
+    private Boolean _deliveryFailed;
+
+    private Boolean _undeliverableHere;
+
+    private Map _messageAnnotations;
+
+    public Boolean getDeliveryFailed()
+    {
+        return _deliveryFailed;
+    }
+
+    public void setDeliveryFailed(Boolean deliveryFailed)
+    {
+        _deliveryFailed = deliveryFailed;
+    }
+
+    public Boolean getUndeliverableHere()
+    {
+        return _undeliverableHere;
+    }
+
+    public void setUndeliverableHere(Boolean undeliverableHere)
+    {
+        _undeliverableHere = undeliverableHere;
+    }
+
+    public Map getMessageAnnotations()
+    {
+        return _messageAnnotations;
+    }
+
+    public void setMessageAnnotations(Map messageAnnotations)
+    {
+        _messageAnnotations = messageAnnotations;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Modified{");
+        final int origLength = builder.length();
+
+        if(_deliveryFailed != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("deliveryFailed=").append(_deliveryFailed);
+        }
+
+        if(_undeliverableHere != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("undeliverableHere=").append(_undeliverableHere);
+        }
+
+        if(_messageAnnotations != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("messageAnnotations=").append(_messageAnnotations);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Properties.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Properties.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Properties.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Properties.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,333 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+import org.apache.qpid.amqp_1_0.messaging.SectionEncoder;
+
+
+import java.util.Date;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Properties
+  implements Section
+  {
+
+
+    private Object _messageId;
+
+    private Binary _userId;
+
+    private String _to;
+
+    private String _subject;
+
+    private String _replyTo;
+
+    private Object _correlationId;
+
+    private Symbol _contentType;
+
+    private Symbol _contentEncoding;
+
+    private Date _absoluteExpiryTime;
+
+    private Date _creationTime;
+
+    private String _groupId;
+
+    private UnsignedInteger _groupSequence;
+
+    private String _replyToGroupId;
+
+    public Object getMessageId()
+    {
+        return _messageId;
+    }
+
+    public void setMessageId(Object messageId)
+    {
+        _messageId = messageId;
+    }
+
+    public Binary getUserId()
+    {
+        return _userId;
+    }
+
+    public void setUserId(Binary userId)
+    {
+        _userId = userId;
+    }
+
+    public String getTo()
+    {
+        return _to;
+    }
+
+    public void setTo(String to)
+    {
+        _to = to;
+    }
+
+    public String getSubject()
+    {
+        return _subject;
+    }
+
+    public void setSubject(String subject)
+    {
+        _subject = subject;
+    }
+
+    public String getReplyTo()
+    {
+        return _replyTo;
+    }
+
+    public void setReplyTo(String replyTo)
+    {
+        _replyTo = replyTo;
+    }
+
+    public Object getCorrelationId()
+    {
+        return _correlationId;
+    }
+
+    public void setCorrelationId(Object correlationId)
+    {
+        _correlationId = correlationId;
+    }
+
+    public Symbol getContentType()
+    {
+        return _contentType;
+    }
+
+    public void setContentType(Symbol contentType)
+    {
+        _contentType = contentType;
+    }
+
+    public Symbol getContentEncoding()
+    {
+        return _contentEncoding;
+    }
+
+    public void setContentEncoding(Symbol contentEncoding)
+    {
+        _contentEncoding = contentEncoding;
+    }
+
+    public Date getAbsoluteExpiryTime()
+    {
+        return _absoluteExpiryTime;
+    }
+
+    public void setAbsoluteExpiryTime(Date absoluteExpiryTime)
+    {
+        _absoluteExpiryTime = absoluteExpiryTime;
+    }
+
+    public Date getCreationTime()
+    {
+        return _creationTime;
+    }
+
+    public void setCreationTime(Date creationTime)
+    {
+        _creationTime = creationTime;
+    }
+
+    public String getGroupId()
+    {
+        return _groupId;
+    }
+
+    public void setGroupId(String groupId)
+    {
+        _groupId = groupId;
+    }
+
+    public UnsignedInteger getGroupSequence()
+    {
+        return _groupSequence;
+    }
+
+    public void setGroupSequence(UnsignedInteger groupSequence)
+    {
+        _groupSequence = groupSequence;
+    }
+
+    public String getReplyToGroupId()
+    {
+        return _replyToGroupId;
+    }
+
+    public void setReplyToGroupId(String replyToGroupId)
+    {
+        _replyToGroupId = replyToGroupId;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Properties{");
+        final int origLength = builder.length();
+
+        if(_messageId != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("messageId=").append(_messageId);
+        }
+
+        if(_userId != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("userId=").append(_userId);
+        }
+
+        if(_to != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("to=").append(_to);
+        }
+
+        if(_subject != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("subject=").append(_subject);
+        }
+
+        if(_replyTo != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("replyTo=").append(_replyTo);
+        }
+
+        if(_correlationId != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("correlationId=").append(_correlationId);
+        }
+
+        if(_contentType != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("contentType=").append(_contentType);
+        }
+
+        if(_contentEncoding != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("contentEncoding=").append(_contentEncoding);
+        }
+
+        if(_absoluteExpiryTime != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("absoluteExpiryTime=").append(_absoluteExpiryTime);
+        }
+
+        if(_creationTime != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("creationTime=").append(_creationTime);
+        }
+
+        if(_groupId != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("groupId=").append(_groupId);
+        }
+
+        if(_groupSequence != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("groupSequence=").append(_groupSequence);
+        }
+
+        if(_replyToGroupId != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("replyToGroupId=").append(_replyToGroupId);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+      public Binary encode(final SectionEncoder encoder)
+      {
+        encoder.reset();
+        encoder.encodeObject(this);
+        return encoder.getEncoding();
+      }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Received.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Received.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Received.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Received.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,88 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Received
+  implements org.apache.qpid.amqp_1_0.type.DeliveryState
+  {
+
+
+    private UnsignedInteger _sectionNumber;
+
+    private UnsignedLong _sectionOffset;
+
+    public UnsignedInteger getSectionNumber()
+    {
+        return _sectionNumber;
+    }
+
+    public void setSectionNumber(UnsignedInteger sectionNumber)
+    {
+        _sectionNumber = sectionNumber;
+    }
+
+    public UnsignedLong getSectionOffset()
+    {
+        return _sectionOffset;
+    }
+
+    public void setSectionOffset(UnsignedLong sectionOffset)
+    {
+        _sectionOffset = sectionOffset;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Received{");
+        final int origLength = builder.length();
+
+        if(_sectionNumber != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("sectionNumber=").append(_sectionNumber);
+        }
+
+        if(_sectionOffset != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("sectionOffset=").append(_sectionOffset);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Rejected.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Rejected.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Rejected.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Rejected.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,70 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.transport.Error;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Rejected
+  implements org.apache.qpid.amqp_1_0.type.DeliveryState, Outcome
+  {
+
+
+    private Error _error;
+
+    public Error getError()
+    {
+        return _error;
+    }
+
+    public void setError(Error error)
+    {
+        _error = error;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Rejected{");
+        final int origLength = builder.length();
+
+        if(_error != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("error=").append(_error);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Released.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Released.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Released.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Released.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,46 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Released
+  implements org.apache.qpid.amqp_1_0.type.DeliveryState, Outcome
+  {
+
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Released{");
+        final int origLength = builder.length();
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Source.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Source.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Source.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Source.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,280 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Source
+  implements org.apache.qpid.amqp_1_0.type.Source
+  {
+
+
+    private String _address;
+
+    private TerminusDurability _durable;
+
+    private TerminusExpiryPolicy _expiryPolicy;
+
+    private UnsignedInteger _timeout;
+
+    private Boolean _dynamic;
+
+    private Map _dynamicNodeProperties;
+
+    private DistributionMode _distributionMode;
+
+    private Map _filter;
+
+    private Outcome _defaultOutcome;
+
+    private Symbol[] _outcomes;
+
+    private Symbol[] _capabilities;
+
+    public String getAddress()
+    {
+        return _address;
+    }
+
+    public void setAddress(String address)
+    {
+        _address = address;
+    }
+
+    public TerminusDurability getDurable()
+    {
+        return _durable;
+    }
+
+    public void setDurable(TerminusDurability durable)
+    {
+        _durable = durable;
+    }
+
+    public TerminusExpiryPolicy getExpiryPolicy()
+    {
+        return _expiryPolicy;
+    }
+
+    public void setExpiryPolicy(TerminusExpiryPolicy expiryPolicy)
+    {
+        _expiryPolicy = expiryPolicy;
+    }
+
+    public UnsignedInteger getTimeout()
+    {
+        return _timeout;
+    }
+
+    public void setTimeout(UnsignedInteger timeout)
+    {
+        _timeout = timeout;
+    }
+
+    public Boolean getDynamic()
+    {
+        return _dynamic;
+    }
+
+    public void setDynamic(Boolean dynamic)
+    {
+        _dynamic = dynamic;
+    }
+
+    public Map getDynamicNodeProperties()
+    {
+        return _dynamicNodeProperties;
+    }
+
+    public void setDynamicNodeProperties(Map dynamicNodeProperties)
+    {
+        _dynamicNodeProperties = dynamicNodeProperties;
+    }
+
+    public DistributionMode getDistributionMode()
+    {
+        return _distributionMode;
+    }
+
+    public void setDistributionMode(DistributionMode distributionMode)
+    {
+        _distributionMode = distributionMode;
+    }
+
+    public Map getFilter()
+    {
+        return _filter;
+    }
+
+    public void setFilter(Map filter)
+    {
+        _filter = filter;
+    }
+
+    public Outcome getDefaultOutcome()
+    {
+        return _defaultOutcome;
+    }
+
+    public void setDefaultOutcome(Outcome defaultOutcome)
+    {
+        _defaultOutcome = defaultOutcome;
+    }
+
+    public Symbol[] getOutcomes()
+    {
+        return _outcomes;
+    }
+
+    public void setOutcomes(Symbol[] outcomes)
+    {
+        _outcomes = outcomes;
+    }
+
+    public Symbol[] getCapabilities()
+    {
+        return _capabilities;
+    }
+
+    public void setCapabilities(Symbol[] capabilities)
+    {
+        _capabilities = capabilities;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Source{");
+        final int origLength = builder.length();
+
+        if(_address != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("address=").append(_address);
+        }
+
+        if(_durable != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("durable=").append(_durable);
+        }
+
+        if(_expiryPolicy != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("expiryPolicy=").append(_expiryPolicy);
+        }
+
+        if(_timeout != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("timeout=").append(_timeout);
+        }
+
+        if(_dynamic != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("dynamic=").append(_dynamic);
+        }
+
+        if(_dynamicNodeProperties != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("dynamicNodeProperties=").append(_dynamicNodeProperties);
+        }
+
+        if(_distributionMode != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("distributionMode=").append(_distributionMode);
+        }
+
+        if(_filter != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("filter=").append(_filter);
+        }
+
+        if(_defaultOutcome != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("defaultOutcome=").append(_defaultOutcome);
+        }
+
+        if(_outcomes != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("outcomes=").append(_outcomes);
+        }
+
+        if(_capabilities != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("capabilities=").append(_capabilities);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/StdDistMode.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/StdDistMode.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/StdDistMode.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/StdDistMode.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,95 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class StdDistMode
+  implements DistributionMode, RestrictedType<Symbol>
+  
+  {
+
+
+
+    private final Symbol _val;
+
+    
+    public static final StdDistMode MOVE = new StdDistMode(Symbol.valueOf("move"));
+    
+    public static final StdDistMode COPY = new StdDistMode(Symbol.valueOf("copy"));
+    
+
+
+    private StdDistMode(Symbol val)
+    {
+        _val = val;
+    }
+
+    public Symbol getValue()
+    {
+        return _val;
+    }
+
+    public String toString()
+    {
+        
+        if(this == MOVE)
+        {
+            return "move";
+        }
+        
+        if(this == COPY)
+        {
+            return "copy";
+        }
+        
+        else
+        {
+            return String.valueOf(_val);
+        }
+    }
+
+    public static StdDistMode valueOf(Object obj)
+    {
+        Symbol val = (Symbol) obj;
+
+        if(MOVE._val.equals(val))
+        {
+            return MOVE;
+        }
+    
+        if(COPY._val.equals(val))
+        {
+            return COPY;
+        }
+    
+        // TODO ERROR
+        return null;
+    }
+
+
+
+  }

Added: qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Target.java
URL: http://svn.apache.org/viewvc/qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Target.java?rev=1157566&view=auto
==============================================================================
--- qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Target.java (added)
+++ qpid/branches/rg-amqp-1-0-sandbox/qpid/java/amqp-1-0-common/src/main/java/org/apache/qpid/amqp_1_0/type/messaging/Target.java Sun Aug 14 17:14:51 2011
@@ -0,0 +1,196 @@
+
+/*
+*
+* 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.qpid.amqp_1_0.type.messaging;
+
+
+
+import java.util.Map;
+
+
+import org.apache.qpid.amqp_1_0.type.*;
+
+public class Target
+  implements org.apache.qpid.amqp_1_0.type.Target
+  {
+
+
+    private String _address;
+
+    private TerminusDurability _durable;
+
+    private TerminusExpiryPolicy _expiryPolicy;
+
+    private UnsignedInteger _timeout;
+
+    private Boolean _dynamic;
+
+    private Map _dynamicNodeProperties;
+
+    private Symbol[] _capabilities;
+
+    public String getAddress()
+    {
+        return _address;
+    }
+
+    public void setAddress(String address)
+    {
+        _address = address;
+    }
+
+    public TerminusDurability getDurable()
+    {
+        return _durable;
+    }
+
+    public void setDurable(TerminusDurability durable)
+    {
+        _durable = durable;
+    }
+
+    public TerminusExpiryPolicy getExpiryPolicy()
+    {
+        return _expiryPolicy;
+    }
+
+    public void setExpiryPolicy(TerminusExpiryPolicy expiryPolicy)
+    {
+        _expiryPolicy = expiryPolicy;
+    }
+
+    public UnsignedInteger getTimeout()
+    {
+        return _timeout;
+    }
+
+    public void setTimeout(UnsignedInteger timeout)
+    {
+        _timeout = timeout;
+    }
+
+    public Boolean getDynamic()
+    {
+        return _dynamic;
+    }
+
+    public void setDynamic(Boolean dynamic)
+    {
+        _dynamic = dynamic;
+    }
+
+    public Map getDynamicNodeProperties()
+    {
+        return _dynamicNodeProperties;
+    }
+
+    public void setDynamicNodeProperties(Map dynamicNodeProperties)
+    {
+        _dynamicNodeProperties = dynamicNodeProperties;
+    }
+
+    public Symbol[] getCapabilities()
+    {
+        return _capabilities;
+    }
+
+    public void setCapabilities(Symbol[] capabilities)
+    {
+        _capabilities = capabilities;
+    }
+
+    @Override
+    public String toString()
+    {
+        StringBuilder builder = new StringBuilder("Target{");
+        final int origLength = builder.length();
+
+        if(_address != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("address=").append(_address);
+        }
+
+        if(_durable != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("durable=").append(_durable);
+        }
+
+        if(_expiryPolicy != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("expiryPolicy=").append(_expiryPolicy);
+        }
+
+        if(_timeout != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("timeout=").append(_timeout);
+        }
+
+        if(_dynamic != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("dynamic=").append(_dynamic);
+        }
+
+        if(_dynamicNodeProperties != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("dynamicNodeProperties=").append(_dynamicNodeProperties);
+        }
+
+        if(_capabilities != null)
+        {
+            if(builder.length() != origLength)
+            {
+                builder.append(',');
+            }
+            builder.append("capabilities=").append(_capabilities);
+        }
+
+        builder.append('}');
+        return builder.toString();
+    }
+
+
+  }



---------------------------------------------------------------------
Apache Qpid - AMQP Messaging Implementation
Project:      http://qpid.apache.org
Use/Interact: mailto:commits-subscribe@qpid.apache.org