You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ac...@apache.org on 2017/01/09 15:25:03 UTC

[27/34] qpid-proton git commit: PROTON-1385: remove proton-j from the existing repo, it now has its own repo at: https://git-wip-us.apache.org/repos/asf/qpid-proton-j.git

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/Binary.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Binary.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/Binary.java
deleted file mode 100644
index aac3fc5..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Binary.java
+++ /dev/null
@@ -1,187 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-import java.nio.ByteBuffer;
-import java.util.Collection;
-
-public final class Binary
-{
-
-    private final byte[] _data;
-    private final int _offset;
-    private final int _length;
-    private int _hashCode;
-
-    public Binary(final byte[] data)
-    {
-        this(data, 0, data.length);
-    }
-
-    public Binary(final byte[] data, final int offset, final int length)
-    {
-        _data = data;
-        _offset = offset;
-        _length = length;
-    }
-
-    public ByteBuffer asByteBuffer()
-    {
-        return ByteBuffer.wrap(_data, _offset, _length);
-    }
-
-    @Override
-    public final int hashCode()
-    {
-        int hc = _hashCode;
-        if(hc == 0)
-        {
-            for (int i = 0; i < _length; i++)
-            {
-                hc = 31*hc + (0xFF & _data[_offset + i]);
-            }
-            _hashCode = hc;
-        }
-        return hc;
-    }
-
-    @Override
-    public final boolean equals(Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        Binary buf = (Binary) o;
-        final int size = _length;
-        if (size != buf._length)
-        {
-            return false;
-        }
-
-        final byte[] myData = _data;
-        final byte[] theirData = buf._data;
-        int myOffset = _offset;
-        int theirOffset = buf._offset;
-        final int myLimit = myOffset + size;
-
-        while(myOffset < myLimit)
-        {
-            if (myData[myOffset++] != theirData[theirOffset++])
-            {
-                return false;
-            }
-        }
-
-        return true;
-    }
-
-
-    public int getArrayOffset()
-    {
-        return _offset;
-    }
-
-    public byte[] getArray()
-    {
-        return _data;
-    }
-
-    public int getLength()
-    {
-        return _length;
-    }
-
-    public String toString()
-    {
-        StringBuilder str = new StringBuilder();
-
-
-        for (int i = 0; i < _length; i++)
-        {
-            byte c = _data[_offset + i];
-
-            if (c > 31 && c < 127 && c != '\\')
-            {
-                str.append((char)c);
-            }
-            else
-            {
-                str.append(String.format("\\x%02x", c));
-            }
-        }
-
-        return str.toString();
-
-    }
-
-    public static Binary combine(final Collection<Binary> binaries)
-    {
-
-        if(binaries.size() == 1)
-        {
-            return binaries.iterator().next();
-        }
-
-        int size = 0;
-        for(Binary binary : binaries)
-        {
-            size += binary.getLength();
-        }
-        byte[] data = new byte[size];
-        int offset = 0;
-        for(Binary binary : binaries)
-        {
-            System.arraycopy(binary._data, binary._offset, data, offset, binary._length);
-            offset += binary._length;
-        }
-        return new Binary(data);
-    }
-
-    public Binary subBinary(final int offset, final int length)
-    {
-        return new Binary(_data, _offset+offset, length);
-    }
-
-    public static Binary create(ByteBuffer buffer) 
-    {
-        if( buffer == null )
-            return null;
-        if( buffer.isDirect() || buffer.isReadOnly() )
-        {
-            byte data[] = new byte [buffer.remaining()];
-            ByteBuffer dup = buffer.duplicate();
-            dup.get(data);
-            return new Binary(data);
-        }
-        else 
-        {
-            return new Binary(buffer.array(), buffer.arrayOffset()+buffer.position(), buffer.remaining());
-        }
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal128.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal128.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal128.java
deleted file mode 100644
index 2eea815..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal128.java
+++ /dev/null
@@ -1,152 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-import java.math.BigDecimal;
-import java.nio.ByteBuffer;
-
-public final class Decimal128 extends Number
-{
-    private final BigDecimal _underlying;
-    private final long _msb;
-    private final long _lsb;
-
-    public Decimal128(BigDecimal underlying)
-    {
-        _underlying = underlying;
-
-        _msb = calculateMostSignificantBits(underlying);
-        _lsb = calculateLeastSignificantBits(underlying);
-    }
-
-
-    public Decimal128(final long msb, final long lsb)
-    {
-        _msb = msb;
-        _lsb = lsb;
-
-        _underlying = calculateBigDecimal(msb, lsb);
-
-    }
-
-    public Decimal128(byte[] data)
-    {
-        this(ByteBuffer.wrap(data));
-    }
-
-    private Decimal128(final ByteBuffer buffer)
-    {
-        this(buffer.getLong(),buffer.getLong());
-    }
-
-    private static long calculateMostSignificantBits(final BigDecimal underlying)
-    {
-        return 0;  //TODO.
-    }
-
-    private static long calculateLeastSignificantBits(final BigDecimal underlying)
-    {
-        return 0;  //TODO.
-    }
-
-    private static BigDecimal calculateBigDecimal(final long msb, final long lsb)
-    {
-        return BigDecimal.ZERO;  //TODO.
-    }
-
-    @Override
-    public int intValue()
-    {
-        return _underlying.intValue();
-    }
-
-    @Override
-    public long longValue()
-    {
-        return _underlying.longValue();
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return _underlying.floatValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return _underlying.doubleValue();
-    }
-
-    public long getMostSignificantBits()
-    {
-        return _msb;
-    }
-
-    public long getLeastSignificantBits()
-    {
-        return _lsb;
-    }
-
-    public byte[] asBytes()
-    {
-        byte[] bytes = new byte[16];
-        ByteBuffer buf = ByteBuffer.wrap(bytes);
-        buf.putLong(getMostSignificantBits());
-        buf.putLong(getLeastSignificantBits());
-        return bytes;
-    }
-
-    @Override
-    public boolean equals(final Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        final Decimal128 that = (Decimal128) o;
-
-        if (_lsb != that._lsb)
-        {
-            return false;
-        }
-        if (_msb != that._msb)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    @Override
-    public int hashCode()
-    {
-        int result = (int) (_msb ^ (_msb >>> 32));
-        result = 31 * result + (int) (_lsb ^ (_lsb >>> 32));
-        return result;
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal32.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal32.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal32.java
deleted file mode 100644
index 50ced8a..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal32.java
+++ /dev/null
@@ -1,110 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-import java.math.BigDecimal;
-
-public final class Decimal32 extends Number
-{
-    private final BigDecimal _underlying;
-    private final int _bits;
-
-    public Decimal32(BigDecimal underlying)
-    {
-        _underlying = underlying;
-        _bits = calculateBits( underlying );
-    }
-
-    public Decimal32(final int bits)
-    {
-        _bits = bits;
-        _underlying = calculateBigDecimal(bits);
-    }
-
-    static int calculateBits(final BigDecimal underlying)
-    {
-        return 0;  //TODO.
-    }
-
-    static BigDecimal calculateBigDecimal(int bits)
-    {
-        return BigDecimal.ZERO; // TODO
-    }
-
-
-    @Override
-    public int intValue()
-    {
-        return _underlying.intValue();
-    }
-
-    @Override
-    public long longValue()
-    {
-        return _underlying.longValue();
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return _underlying.floatValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return _underlying.doubleValue();
-    }
-
-    public int getBits()
-    {
-        return _bits;
-    }
-
-    @Override
-    public boolean equals(final Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        final Decimal32 decimal32 = (Decimal32) o;
-
-        if (_bits != decimal32._bits)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return _bits;
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal64.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal64.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal64.java
deleted file mode 100644
index e5277ae..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Decimal64.java
+++ /dev/null
@@ -1,112 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-import java.math.BigDecimal;
-
-public final class Decimal64 extends Number
-{
-    private final BigDecimal _underlying;
-    private final long _bits;
-
-    public Decimal64(BigDecimal underlying)
-    {
-        _underlying = underlying;
-        _bits = calculateBits(underlying);
-
-    }
-
-
-    public Decimal64(final long bits)
-    {
-        _bits = bits;
-        _underlying = calculateBigDecimal(bits);
-    }
-
-    static BigDecimal calculateBigDecimal(final long bits)
-    {
-        return BigDecimal.ZERO;
-    }
-
-    static long calculateBits(final BigDecimal underlying)
-    {
-        return 0l; // TODO
-    }
-
-
-    @Override
-    public int intValue()
-    {
-        return _underlying.intValue();
-    }
-
-    @Override
-    public long longValue()
-    {
-        return _underlying.longValue();
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return _underlying.floatValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return _underlying.doubleValue();
-    }
-
-    public long getBits()
-    {
-        return _bits;
-    }
-
-    @Override
-    public boolean equals(final Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        final Decimal64 decimal64 = (Decimal64) o;
-
-        if (_bits != decimal64._bits)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return (int) (_bits ^ (_bits >>> 32));
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/DescribedType.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/DescribedType.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/DescribedType.java
deleted file mode 100644
index 78a98f6..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/DescribedType.java
+++ /dev/null
@@ -1,27 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-public interface DescribedType
-{
-    public Object getDescriptor();
-    public Object getDescribed();
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/Symbol.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Symbol.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/Symbol.java
deleted file mode 100644
index 17e6177..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/Symbol.java
+++ /dev/null
@@ -1,94 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-import java.util.concurrent.ConcurrentHashMap;
-
-public final class Symbol implements Comparable<Symbol>, CharSequence
-{
-    private final String _underlying;
-    private static final ConcurrentHashMap<String, Symbol> _symbols = new ConcurrentHashMap<String, Symbol>(2048);
-
-    private Symbol(String underlying)
-    {
-        _underlying = underlying;
-    }
-
-    public int length()
-    {
-        return _underlying.length();
-    }
-
-    public int compareTo(Symbol o)
-    {
-        return _underlying.compareTo(o._underlying);
-    }
-
-    public char charAt(int index)
-    {
-        return _underlying.charAt(index);
-    }
-
-    public CharSequence subSequence(int beginIndex, int endIndex)
-    {
-        return _underlying.subSequence(beginIndex, endIndex);
-    }
-
-    @Override
-    public String toString()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return _underlying.hashCode();
-    }
-
-    public static Symbol valueOf(String symbolVal)
-    {
-        return getSymbol(symbolVal);
-    }
-
-    public static Symbol getSymbol(String symbolVal)
-    {
-        if(symbolVal == null)
-        {
-            return null;
-        }
-        Symbol symbol = _symbols.get(symbolVal);
-        if(symbol == null)
-        {
-            symbolVal = symbolVal.intern();
-            symbol = new Symbol(symbolVal);
-            Symbol existing;
-            if((existing = _symbols.putIfAbsent(symbolVal, symbol)) != null)
-            {
-                symbol = existing;
-            }
-        }
-        return symbol;
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnknownDescribedType.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnknownDescribedType.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnknownDescribedType.java
deleted file mode 100644
index 5314d31..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnknownDescribedType.java
+++ /dev/null
@@ -1,88 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-public class UnknownDescribedType implements DescribedType
-{
-    private final Object _descriptor;
-    private final Object _described;
-
-    public UnknownDescribedType(final Object descriptor, final Object described)
-    {
-        _descriptor = descriptor;
-        _described = described;
-    }
-
-    @Override
-    public Object getDescriptor()
-    {
-        return _descriptor;
-    }
-
-    @Override
-    public Object getDescribed()
-    {
-        return _described;
-    }
-
-    @Override
-    public boolean equals(final Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        final UnknownDescribedType that = (UnknownDescribedType) o;
-
-        if (_described != null ? !_described.equals(that._described) : that._described != null)
-        {
-            return false;
-        }
-        if (_descriptor != null ? !_descriptor.equals(that._descriptor) : that._descriptor != null)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    @Override
-    public int hashCode()
-    {
-        int result = _descriptor != null ? _descriptor.hashCode() : 0;
-        result = 31 * result + (_described != null ? _described.hashCode() : 0);
-        return result;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "UnknownDescribedType{" +
-               "descriptor=" + _descriptor +
-               ", described=" + _described +
-               '}';
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedByte.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedByte.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedByte.java
deleted file mode 100644
index 7815915..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedByte.java
+++ /dev/null
@@ -1,134 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-public final class UnsignedByte extends Number implements Comparable<UnsignedByte>
-{
-    private final byte _underlying;
-    private static final UnsignedByte[] cachedValues = new UnsignedByte[256];
-
-    static
-    {
-        for(int i = 0; i<256; i++)
-        {
-            cachedValues[i] = new UnsignedByte((byte)i);
-        }
-    }
-
-    public UnsignedByte(byte underlying)
-    {
-        _underlying = underlying;
-    }
-
-    @Override
-    public byte byteValue()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public short shortValue()
-    {
-        return (short) intValue();
-    }
-
-    @Override
-    public int intValue()
-    {
-        return ((int)_underlying) & 0xFF;
-    }
-
-    @Override
-    public long longValue()
-    {
-        return ((long) _underlying) & 0xFFl;
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return (float) longValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return (double) longValue();
-    }
-
-    @Override
-    public boolean equals(Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        UnsignedByte that = (UnsignedByte) o;
-
-        if (_underlying != that._underlying)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    public int compareTo(UnsignedByte o)
-    {
-        return Integer.signum(intValue() - o.intValue());
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public String toString()
-    {
-        return String.valueOf(intValue());
-    }
-
-    public static UnsignedByte valueOf(byte underlying)
-    {
-        final int index = ((int) underlying) & 0xFF;
-        return cachedValues[index];
-    }
-
-    public static UnsignedByte valueOf(final String value)
-            throws NumberFormatException
-    {
-        int intVal = Integer.parseInt(value);
-        if(intVal < 0 || intVal >= (1<<8))
-        {
-            throw new NumberFormatException("Value \""+value+"\" lies outside the range [" + 0 + "-" + (1<<8) +").");
-        }
-        return valueOf((byte)intVal);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedInteger.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedInteger.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedInteger.java
deleted file mode 100644
index aeadb40..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedInteger.java
+++ /dev/null
@@ -1,149 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-public final class UnsignedInteger extends Number implements Comparable<UnsignedInteger>
-{
-    private final int _underlying;
-    private static final UnsignedInteger[] cachedValues = new UnsignedInteger[256];
-
-    static
-    {
-        for(int i = 0; i < 256; i++)
-        {
-            cachedValues[i] = new UnsignedInteger(i);
-        }
-    }
-
-    public static final UnsignedInteger ZERO = cachedValues[0];
-    public static final UnsignedInteger ONE = cachedValues[1];
-    public static final UnsignedInteger MAX_VALUE = new UnsignedInteger(0xffffffff);
-
-
-    public UnsignedInteger(int underlying)
-    {
-        _underlying = underlying;
-    }
-
-    @Override
-    public int intValue()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public long longValue()
-    {
-        return ((long) _underlying) & 0xFFFFFFFFl;
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return (float) longValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return (double) longValue();
-    }
-
-    @Override
-    public boolean equals(Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        UnsignedInteger that = (UnsignedInteger) o;
-
-        if (_underlying != that._underlying)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    public int compareTo(UnsignedInteger o)
-    {
-        return Long.signum(longValue() - o.longValue());
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public String toString()
-    {
-        return String.valueOf(longValue());
-    }
-
-    public static UnsignedInteger valueOf(int underlying)
-    {
-        if((underlying & 0xFFFFFF00) == 0)
-        {
-            return cachedValues[underlying];
-        }
-        else
-        {
-            return new UnsignedInteger(underlying);
-        }
-    }
-
-    public UnsignedInteger add(final UnsignedInteger i)
-    {
-        int val = _underlying + i._underlying;
-        return UnsignedInteger.valueOf(val);
-    }
-
-    public UnsignedInteger subtract(final UnsignedInteger i)
-    {
-        int val = _underlying - i._underlying;
-        return UnsignedInteger.valueOf(val);
-    }
-
-    public static UnsignedInteger valueOf(final String value)
-    {
-        long longVal = Long.parseLong(value);
-        return valueOf(longVal);
-    }
-
-    public static UnsignedInteger valueOf(final long longVal)
-    {
-        if(longVal < 0L || longVal >= (1L<<32))
-        {
-            throw new NumberFormatException("Value \""+longVal+"\" lies outside the range [" + 0L + "-" + (1L<<32) +").");
-        }
-        return valueOf((int)longVal);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedLong.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedLong.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedLong.java
deleted file mode 100644
index 1fa5b85..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedLong.java
+++ /dev/null
@@ -1,160 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-import java.math.BigInteger;
-
-public final class UnsignedLong extends Number implements Comparable<UnsignedLong>
-{
-    private static final BigInteger TWO_TO_THE_SIXTY_FOUR = new BigInteger( new byte[] { (byte) 1, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0, (byte) 0 });
-    private static final BigInteger LONG_MAX_VALUE = BigInteger.valueOf(Long.MAX_VALUE);
-
-    private static final UnsignedLong[] cachedValues = new UnsignedLong[256];
-
-    static
-    {
-        for(int i = 0; i<256; i++)
-        {
-            cachedValues[i] = new UnsignedLong(i);
-        }
-    }
-
-    public static final UnsignedLong ZERO = cachedValues[0];
-
-    private final long _underlying;
-
-
-    public UnsignedLong(long underlying)
-    {
-        _underlying = underlying;
-    }
-
-    @Override
-    public int intValue()
-    {
-        return (int) _underlying;
-    }
-
-    @Override
-    public long longValue()
-    {
-        return _underlying;
-    }
-
-    public BigInteger bigIntegerValue()
-    {
-        if(_underlying >= 0L)
-        {
-            return BigInteger.valueOf(_underlying);
-        }
-        else
-        {
-            return TWO_TO_THE_SIXTY_FOUR.add(BigInteger.valueOf(_underlying));
-        }
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return (float) longValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return (double) longValue();
-    }
-
-    @Override
-    public boolean equals(Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        UnsignedLong that = (UnsignedLong) o;
-
-        if (_underlying != that._underlying)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    public int compareTo(UnsignedLong o)
-    {
-        return bigIntegerValue().compareTo(o.bigIntegerValue());
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return (int)(_underlying ^ (_underlying >>> 32));
-    }
-
-    @Override
-    public String toString()
-    {
-        return String.valueOf(bigIntegerValue());
-    }
-
-    public static UnsignedLong valueOf(long underlying)
-    {
-        if((underlying & 0xFFL) == underlying)
-        {
-            return cachedValues[(int)underlying];
-        }
-        else
-        {
-            return new UnsignedLong(underlying);
-        }
-    }
-
-    public static UnsignedLong valueOf(final String value)
-    {
-        BigInteger bigInt = new BigInteger(value);
-
-        return valueOf(bigInt);
-    }
-
-    public static UnsignedLong valueOf(BigInteger bigInt)
-    {
-        if(bigInt.signum() == -1 || bigInt.bitLength() > 64)
-        {
-            throw new NumberFormatException("Value \""+bigInt+"\" lies outside the range [0 - 2^64).");
-        }
-        else if(bigInt.compareTo(LONG_MAX_VALUE)>=0)
-        {
-            return UnsignedLong.valueOf(bigInt.longValue());
-        }
-        else
-        {
-            return UnsignedLong.valueOf(TWO_TO_THE_SIXTY_FOUR.subtract(bigInt).negate().longValue());
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedShort.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedShort.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedShort.java
deleted file mode 100644
index 8d9d8bd..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/UnsignedShort.java
+++ /dev/null
@@ -1,134 +0,0 @@
-/*
- *
- * 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.proton.amqp;
-
-public final class UnsignedShort extends Number implements Comparable<UnsignedShort>
-{
-    private final short _underlying;
-    private static final UnsignedShort[] cachedValues = new UnsignedShort[256];
-
-    public static final UnsignedShort MAX_VALUE = new UnsignedShort((short) -1);
-
-    static
-    {
-        for(short i = 0; i < 256; i++)
-        {
-            cachedValues[i] = new UnsignedShort(i);
-        }
-    }
-
-    public UnsignedShort(short underlying)
-    {
-        _underlying = underlying;
-    }
-
-    public short shortValue()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public int intValue()
-    {
-        return _underlying & 0xFFFF;
-    }
-
-    @Override
-    public long longValue()
-    {
-        return ((long) _underlying) & 0xFFFFl;
-    }
-
-    @Override
-    public float floatValue()
-    {
-        return (float) intValue();
-    }
-
-    @Override
-    public double doubleValue()
-    {
-        return (double) intValue();
-    }
-
-    @Override
-    public boolean equals(Object o)
-    {
-        if (this == o)
-        {
-            return true;
-        }
-        if (o == null || getClass() != o.getClass())
-        {
-            return false;
-        }
-
-        UnsignedShort that = (UnsignedShort) o;
-
-        if (_underlying != that._underlying)
-        {
-            return false;
-        }
-
-        return true;
-    }
-
-    public int compareTo(UnsignedShort o)
-    {
-        return Integer.signum(intValue() - o.intValue());
-    }
-
-    @Override
-    public int hashCode()
-    {
-        return _underlying;
-    }
-
-    @Override
-    public String toString()
-    {
-        return String.valueOf(longValue());
-    }
-
-    public static UnsignedShort valueOf(short underlying)
-    {
-        if((underlying & 0xFF00) == 0)
-        {
-            return cachedValues[underlying];
-        }
-        else
-        {
-            return new UnsignedShort(underlying);
-        }
-    }
-
-    public static UnsignedShort valueOf(final String value)
-    {
-        int intVal = Integer.parseInt(value);
-        if(intVal < 0 || intVal >= (1<<16))
-        {
-            throw new NumberFormatException("Value \""+value+"\" lies outside the range [" + 0 + "-" + (1<<16) +").");
-        }
-        return valueOf((short)intVal);
-
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Accepted.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Accepted.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Accepted.java
deleted file mode 100644
index d21caaa..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Accepted.java
+++ /dev/null
@@ -1,55 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.Symbol;
-import org.apache.qpid.proton.amqp.transport.DeliveryState;
-
-
-public final class Accepted
-      implements DeliveryState, Outcome
-{
-    public static final Symbol DESCRIPTOR_SYMBOL = Symbol.valueOf("amqp:accepted:list");
-
-    private static final Accepted INSTANCE = new Accepted();
-
-
-    /**
-     *  TODO should this (and other DeliveryStates) have a private constructor??
-     */
-    public Accepted()
-    {
-    }
-
-    @Override
-    public String toString()
-    {
-        return "Accepted{}";
-    }
-
-    public static Accepted getInstance()
-    {
-        return INSTANCE;
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpSequence.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpSequence.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpSequence.java
deleted file mode 100644
index 2a07613..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpSequence.java
+++ /dev/null
@@ -1,52 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.List;
-
-public final class AmqpSequence
-      implements Section
-{
-    private final List _value;
-
-    public AmqpSequence(List value)
-    {
-        _value = value;
-    }
-
-    public List getValue()
-    {
-        return _value;
-    }
-
-
-    @Override
-    public String toString()
-    {
-        return "AmqpSequence{" +
-               _value +
-               '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpValue.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpValue.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpValue.java
deleted file mode 100644
index d6ae49e..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/AmqpValue.java
+++ /dev/null
@@ -1,47 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-public final class AmqpValue
-      implements  Section
-{
-    private final Object _value;
-
-    public AmqpValue(Object value)
-    {
-        _value = value;
-    }
-
-    public Object getValue()
-    {
-        return _value;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "AmqpValue{" + _value + '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/ApplicationProperties.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/ApplicationProperties.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/ApplicationProperties.java
deleted file mode 100644
index e8cc0de..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/ApplicationProperties.java
+++ /dev/null
@@ -1,49 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Map;
-
-public final class ApplicationProperties
-      implements Section
-{
-    private final Map _value;
-
-    public ApplicationProperties(Map value)
-    {
-        _value = value;
-    }
-
-    public Map getValue()
-    {
-        return _value;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "ApplicationProperties{" + _value + '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Data.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Data.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Data.java
deleted file mode 100644
index c946d14..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Data.java
+++ /dev/null
@@ -1,49 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.Binary;
-
-public final class Data
-      implements Section
-{
-    private final Binary _value;
-
-    public Data(Binary value)
-    {
-        _value = value;
-    }
-
-    public Binary getValue()
-    {
-        return _value;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "Data{" + _value + '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnClose.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnClose.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnClose.java
deleted file mode 100644
index 855b93f..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnClose.java
+++ /dev/null
@@ -1,46 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-public final class DeleteOnClose
-      implements LifetimePolicy
-{
-    private static final DeleteOnClose INSTANCE = new DeleteOnClose();
-
-    private DeleteOnClose()
-    {
-    }
-
-    @Override
-    public String toString()
-    {
-        return "DeleteOnClose{}";
-    }
-
-    public static DeleteOnClose getInstance()
-    {
-        return INSTANCE;
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinks.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinks.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinks.java
deleted file mode 100644
index 3a77f77..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinks.java
+++ /dev/null
@@ -1,46 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-
-public final class DeleteOnNoLinks implements LifetimePolicy
-{
-
-    private static final DeleteOnNoLinks INSTANCE = new DeleteOnNoLinks();
-
-    private DeleteOnNoLinks()
-    {
-    }
-
-    public String toString()
-    {
-        return "DeleteOnNoLinks{}";
-    }
-
-    public static DeleteOnNoLinks getInstance()
-    {
-        return INSTANCE;
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinksOrMessages.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinksOrMessages.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinksOrMessages.java
deleted file mode 100644
index a19789e..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoLinksOrMessages.java
+++ /dev/null
@@ -1,45 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-public final class DeleteOnNoLinksOrMessages
-      implements LifetimePolicy
-{
-    private static final DeleteOnNoLinksOrMessages INSTANCE = new DeleteOnNoLinksOrMessages();
-
-    private DeleteOnNoLinksOrMessages()
-    {
-    }
-
-    public String toString()
-    {
-        return "DeleteOnNoLinksOrMessages{}";
-    }
-
-    public static DeleteOnNoLinksOrMessages getInstance()
-    {
-        return INSTANCE;
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoMessages.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoMessages.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoMessages.java
deleted file mode 100644
index be70005..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeleteOnNoMessages.java
+++ /dev/null
@@ -1,45 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-
-public final class DeleteOnNoMessages implements LifetimePolicy
-{
-    private static final DeleteOnNoMessages INSTANCE = new DeleteOnNoMessages();
-    
-    private DeleteOnNoMessages()
-    {
-    }
-    
-    public String toString()
-    {
-        return "DeleteOnNoMessages{}";
-    }
-
-    public static DeleteOnNoMessages getInstance()
-    {
-        return INSTANCE;
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeliveryAnnotations.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeliveryAnnotations.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeliveryAnnotations.java
deleted file mode 100644
index 9ea5504..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/DeliveryAnnotations.java
+++ /dev/null
@@ -1,50 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Map;
-
-import org.apache.qpid.proton.amqp.Symbol;
-
-public final class DeliveryAnnotations implements Section
-{
-    private final Map<Symbol, Object> _value;
-
-    public DeliveryAnnotations(Map<Symbol, Object> value)
-    {
-        _value = value;
-    }
-
-    public Map<Symbol, Object> getValue()
-    {
-        return _value;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "DeliveryAnnotations{" + _value + '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Footer.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Footer.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Footer.java
deleted file mode 100644
index 4e9a789..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Footer.java
+++ /dev/null
@@ -1,50 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Map;
-
-
-public final class Footer
-      implements  Section
-{
-    private final Map _value;
-
-    public Footer(Map value)
-    {
-        _value = value;
-    }
-
-    public Map getValue()
-    {
-        return _value;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "Footer{" + _value + '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Header.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Header.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Header.java
deleted file mode 100644
index 83b1974..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Header.java
+++ /dev/null
@@ -1,102 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.UnsignedByte;
-import org.apache.qpid.proton.amqp.UnsignedInteger;
-
-
-public final 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()
-    {
-        return "Header{" +
-               "durable=" + _durable +
-               ", priority=" + _priority +
-               ", ttl=" + _ttl +
-               ", firstAcquirer=" + _firstAcquirer +
-               ", deliveryCount=" + _deliveryCount +
-               '}';
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/LifetimePolicy.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/LifetimePolicy.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/LifetimePolicy.java
deleted file mode 100644
index 68b41df..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/LifetimePolicy.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/*
- *
- * 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.proton.amqp.messaging;
-
-public interface LifetimePolicy
-{
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/MessageAnnotations.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/MessageAnnotations.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/MessageAnnotations.java
deleted file mode 100644
index 9bf82d6..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/MessageAnnotations.java
+++ /dev/null
@@ -1,52 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.Symbol;
-
-import java.util.Map;
-
-
-public final class MessageAnnotations implements Section
-{
-
-    private final Map<Symbol, Object> _value;
-
-    public MessageAnnotations(Map<Symbol, Object> value)
-    {
-        _value = value;
-    }
-
-    public Map<Symbol, Object> getValue()
-    {
-        return _value;
-    }
-
-    @Override
-    public String toString()
-    {
-        return "MessageAnnotations{" + _value + '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Modified.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Modified.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Modified.java
deleted file mode 100644
index 9b9a3a3..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Modified.java
+++ /dev/null
@@ -1,78 +0,0 @@
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Map;
-
-import org.apache.qpid.proton.amqp.Symbol;
-import org.apache.qpid.proton.amqp.transport.DeliveryState;
-
-public final class Modified
-      implements DeliveryState, Outcome
-{
-    public static final Symbol DESCRIPTOR_SYMBOL = Symbol.valueOf("amqp:modified:list");
-
-    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()
-    {
-        return "Modified{" +
-               "deliveryFailed=" + _deliveryFailed +
-               ", undeliverableHere=" + _undeliverableHere +
-               ", messageAnnotations=" + _messageAnnotations +
-               '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Outcome.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Outcome.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Outcome.java
deleted file mode 100644
index bd155db..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Outcome.java
+++ /dev/null
@@ -1,26 +0,0 @@
-package org.apache.qpid.proton.amqp.messaging;
-/*
- *
- * 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.
- *
-*/
-
-
-public interface Outcome
-{
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Properties.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Properties.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Properties.java
deleted file mode 100644
index a8c4880..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Properties.java
+++ /dev/null
@@ -1,199 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Date;
-import org.apache.qpid.proton.amqp.Binary;
-import org.apache.qpid.proton.amqp.Symbol;
-import org.apache.qpid.proton.amqp.UnsignedInteger;
-
-
-public final 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()
-    {
-        return "Properties{" +
-               "messageId=" + _messageId +
-               ", userId=" + _userId +
-               ", to='" + _to + '\'' +
-               ", subject='" + _subject + '\'' +
-               ", replyTo='" + _replyTo + '\'' +
-               ", correlationId=" + _correlationId +
-               ", contentType=" + _contentType +
-               ", contentEncoding=" + _contentEncoding +
-               ", absoluteExpiryTime=" + _absoluteExpiryTime +
-               ", creationTime=" + _creationTime +
-               ", groupId='" + _groupId + '\'' +
-               ", groupSequence=" + _groupSequence +
-               ", replyToGroupId='" + _replyToGroupId + '\'' +
-               '}';
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Received.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Received.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Received.java
deleted file mode 100644
index 796934b..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Received.java
+++ /dev/null
@@ -1,69 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.UnsignedInteger;
-import org.apache.qpid.proton.amqp.UnsignedLong;
-import org.apache.qpid.proton.amqp.transport.DeliveryState;
-
-
-
-public final class Received
-      implements 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()
-    {
-        return "Received{" +
-               "sectionNumber=" + _sectionNumber +
-               ", sectionOffset=" + _sectionOffset +
-               '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Rejected.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Rejected.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Rejected.java
deleted file mode 100644
index 3ea3a5b..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Rejected.java
+++ /dev/null
@@ -1,64 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.Symbol;
-import org.apache.qpid.proton.amqp.transport.DeliveryState;
-import org.apache.qpid.proton.amqp.transport.ErrorCondition;
-
-
-public final class Rejected
-      implements DeliveryState, Outcome
-{
-    public static final Symbol DESCRIPTOR_SYMBOL = Symbol.valueOf("amqp:rejected:list");
-
-    private ErrorCondition _error;
-
-    public ErrorCondition getError()
-    {
-        return _error;
-    }
-
-    public void setError(ErrorCondition error)
-    {
-        _error = error;
-    }
-
-    public int size()
-    {
-        return _error != null 
-                  ? 1 
-                  : 0;        
-
-    }
-
-    @Override
-    public String toString()
-    {
-        return "Rejected{" +
-               "error=" + _error +
-               '}';
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Released.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Released.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Released.java
deleted file mode 100644
index c67917f..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Released.java
+++ /dev/null
@@ -1,48 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import org.apache.qpid.proton.amqp.Symbol;
-import org.apache.qpid.proton.amqp.transport.DeliveryState;
-
-
-public final class Released
-      implements DeliveryState, Outcome
-{
-    public static final Symbol DESCRIPTOR_SYMBOL = Symbol.valueOf("amqp:released:list");
-
-    private static final Released INSTANCE = new Released();
-
-    @Override
-    public String toString()
-    {
-        return "Released{}";
-    }
-
-    public static Released getInstance()
-    {
-        return INSTANCE;
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Section.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Section.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Section.java
deleted file mode 100644
index 2bcc4d5..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Section.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/*
- *
- * 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.proton.amqp.messaging;
-
-public interface Section
-{
-}

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Source.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Source.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Source.java
deleted file mode 100644
index e6fffef..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Source.java
+++ /dev/null
@@ -1,113 +0,0 @@
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Arrays;
-import java.util.HashMap;
-import java.util.Map;
-
-import org.apache.qpid.proton.amqp.Symbol;
-
-public final class Source extends Terminus
-      implements org.apache.qpid.proton.amqp.transport.Source
-{
-    private Symbol _distributionMode;
-    private Map _filter;
-    private Outcome _defaultOutcome;
-    private Symbol[] _outcomes;
-
-    private Source(Source other) {
-        super(other);
-        _distributionMode = other._distributionMode;
-        if (other._filter != null)
-            _filter = new HashMap(other._filter);
-        _defaultOutcome = other._defaultOutcome;
-        if (other._outcomes != null)
-            _outcomes = other._outcomes.clone();
-    }
-    
-    public Source() {}
-
-    public Symbol getDistributionMode()
-    {
-        return _distributionMode;
-    }
-
-    public void setDistributionMode(Symbol 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;
-    }
-
-
-    @Override
-    public String toString()
-    {
-        return "Source{" +
-               "address='" + getAddress() + '\'' +
-               ", durable=" + getDurable() +
-               ", expiryPolicy=" + getExpiryPolicy() +
-               ", timeout=" + getTimeout() +
-               ", dynamic=" + getDynamic() +
-               ", dynamicNodeProperties=" + getDynamicNodeProperties() +
-               ", distributionMode=" + _distributionMode +
-               ", filter=" + _filter +
-               ", defaultOutcome=" + _defaultOutcome +
-               ", outcomes=" + (_outcomes == null ? null : Arrays.asList(_outcomes)) +
-               ", capabilities=" + (getCapabilities() == null ? null : Arrays.asList(getCapabilities())) +
-               '}';
-    }
-
-    @Override
-    public org.apache.qpid.proton.amqp.transport.Source copy() {
-        return new Source(this);
-    }
-}
-  
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-proton/blob/ccdcf329/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Target.java
----------------------------------------------------------------------
diff --git a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Target.java b/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Target.java
deleted file mode 100644
index 38678d1..0000000
--- a/proton-j/src/main/java/org/apache/qpid/proton/amqp/messaging/Target.java
+++ /dev/null
@@ -1,57 +0,0 @@
-
-/*
-*
-* 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.proton.amqp.messaging;
-
-import java.util.Arrays;
-
-public final class Target extends Terminus
-      implements org.apache.qpid.proton.amqp.transport.Target
-{
-    private Target(Target other) {
-        super(other);
-    }
-
-    public Target() {
-    }
-
-    @Override
-    public String toString()
-    {
-        return "Target{" +
-               "address='" + getAddress() + '\'' +
-               ", durable=" + getDurable() +
-               ", expiryPolicy=" + getExpiryPolicy() +
-               ", timeout=" + getTimeout() +
-               ", dynamic=" + getDynamic() +
-               ", dynamicNodeProperties=" + getDynamicNodeProperties() +
-               ", capabilities=" + (getCapabilities() == null ? null : Arrays.asList(getCapabilities())) +
-               '}';
-    }
-
-    @Override
-    public org.apache.qpid.proton.amqp.transport.Target copy() {
-        return new Target(this);
-    }
-}
-  
\ No newline at end of file


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org