You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ro...@apache.org on 2014/12/22 17:56:20 UTC

[12/16] qpid-jms git commit: remove tmp module with old client work

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SessionImpl.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SessionImpl.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SessionImpl.java
deleted file mode 100644
index 5f1ddb7..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SessionImpl.java
+++ /dev/null
@@ -1,415 +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.jms.impl;
-
-import java.io.Serializable;
-
-import javax.jms.BytesMessage;
-import javax.jms.Destination;
-import javax.jms.InvalidDestinationException;
-import javax.jms.JMSException;
-import javax.jms.MapMessage;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageListener;
-import javax.jms.MessageProducer;
-import javax.jms.ObjectMessage;
-import javax.jms.Queue;
-import javax.jms.QueueBrowser;
-import javax.jms.Session;
-import javax.jms.StreamMessage;
-import javax.jms.TemporaryQueue;
-import javax.jms.TemporaryTopic;
-import javax.jms.TextMessage;
-import javax.jms.Topic;
-import javax.jms.TopicSubscriber;
-
-import org.apache.qpid.jms.engine.AmqpReceiver;
-import org.apache.qpid.jms.engine.AmqpResourceRequest;
-import org.apache.qpid.jms.engine.AmqpSender;
-import org.apache.qpid.jms.engine.AmqpSession;
-
-public class SessionImpl implements Session
-{
-    private final int _acknowledgeMode;
-    private final AmqpSession _amqpSession;
-    private final ConnectionImpl _connectionImpl;
-    private final DestinationHelper _destinationHelper;
-    private final MessageIdHelper _messageIdHelper;
-
-    public SessionImpl(int acknowledgeMode, AmqpSession amqpSession, ConnectionImpl connectionImpl, DestinationHelper destinationHelper, MessageIdHelper messageIdHelper)
-    {
-        _acknowledgeMode = acknowledgeMode;
-        _amqpSession = amqpSession;
-        _connectionImpl = connectionImpl;
-        _destinationHelper = destinationHelper;
-        _messageIdHelper = messageIdHelper;
-    }
-
-    ConnectionImpl getConnectionImpl()
-    {
-        return _connectionImpl;
-    }
-
-    private SenderImpl createSender(String address, Destination destination) throws JMSException
-    {
-        _connectionImpl.lock();
-        try
-        {
-            AmqpResourceRequest<Void> request = new AmqpResourceRequest<Void>();
-
-            SenderImpl sender = null;
-            synchronized (_connectionImpl.getAmqpConnection())
-            {
-                AmqpSender amqpSender = _amqpSession.createAmqpSender(address);
-                sender = new SenderImpl(this, _connectionImpl, amqpSender, destination);
-                sender.open(request);
-                _connectionImpl.stateChanged();
-            }
-
-            _connectionImpl.waitForResult(request, "Exception while creating sender to: " + address);
-
-            return sender;
-        }
-        finally
-        {
-            _connectionImpl.releaseLock();
-        }
-    }
-
-    private ReceiverImpl createReceiver(String address, Destination recieverDestination) throws JMSException
-    {
-        _connectionImpl.lock();
-        try
-        {
-            AmqpResourceRequest<Void> request = new AmqpResourceRequest<Void>();
-
-            ReceiverImpl receiver = null;
-            AmqpReceiver amqpReceiver = null;
-            synchronized (_connectionImpl.getAmqpConnection())
-            {
-                amqpReceiver = _amqpSession.createAmqpReceiver(address);
-                receiver = new ReceiverImpl(_connectionImpl, this, amqpReceiver, recieverDestination);
-                receiver.open(request);
-                _connectionImpl.stateChanged();
-            }
-
-            _connectionImpl.waitForResult(request, "Exception while creating sender to: " + address);
-
-            //TODO: per-consumer prefetch override?
-
-            if(_connectionImpl.isStarted())
-            {
-                //Issue initial flow for the consumer, if required.
-                //TODO: decide on prefetch behaviour, i.e. whether we defer flow or do it now, and what value to use.
-                receiver.flowIfNecessary();
-                _connectionImpl.stateChanged();
-            }
-
-            return receiver;
-        }
-        finally
-        {
-            _connectionImpl.releaseLock();
-        }
-    }
-
-    public MessageIdHelper getMessageIdHelper()
-    {
-        return _messageIdHelper;
-    }
-
-    DestinationHelper getDestinationHelper()
-    {
-        return _destinationHelper;
-    }
-
-    public void open(AmqpResourceRequest<Void> request) throws JmsTimeoutException, JmsInterruptedException
-    {
-        _amqpSession.open(request);
-    }
-
-    //======= JMS Methods =======
-
-
-    @Override
-    public void close() throws JMSException
-    {
-        _connectionImpl.lock();
-        try
-        {
-            AmqpResourceRequest<Void> request = new AmqpResourceRequest<Void>();
-
-            synchronized (_connectionImpl.getAmqpConnection())
-            {
-                _amqpSession.close(request);
-                _connectionImpl.stateChanged();
-            }
-
-            _connectionImpl.waitForResult(request, "Exception while closing session");
-
-            if(_amqpSession.getSessionError().getCondition() != null)
-            {
-                throw new ConnectionException("Session close failed: " + _amqpSession.getSessionError());
-            }
-        }
-        finally
-        {
-            _connectionImpl.releaseLock();
-        }
-    }
-
-    @Override
-    public MessageProducer createProducer(Destination destination) throws JMSException
-    {
-        //TODO: use destination helper to perform conversion, extract address etc.
-        if(destination == null)
-        {
-            throw new UnsupportedOperationException("Unspecified destinations are not yet supported");
-        }
-        else if (destination instanceof Queue)
-        {
-            Queue queue = (Queue) destination;
-
-            return createSender(queue.getQueueName(), destination);
-        }
-        else if(destination instanceof Topic)
-        {
-            throw new UnsupportedOperationException("Topics are not yet supported");
-        }
-        else
-        {
-            throw new IllegalArgumentException("Destination expected to be a Queue or a Topic but was: " + destination.getClass());
-        }
-
-    }
-
-    @Override
-    public MessageConsumer createConsumer(Destination destination) throws JMSException
-    {
-        if(destination == null)
-        {
-            throw new InvalidDestinationException("Null destination provided");
-        }
-        else if (destination instanceof Queue)
-        {
-            Queue queue = (Queue) destination;
-            return createReceiver(queue.getQueueName(), destination);
-        }
-        else if(destination instanceof Topic)
-        {
-            //TODO: support Topic destinations
-            throw new UnsupportedOperationException("Topics are not yet supported");
-        }
-        else
-        {
-            throw new IllegalArgumentException("Destination expected to be a Queue or a Topic but was: " + destination.getClass());
-        }
-    }
-
-    @Override
-    public BytesMessage createBytesMessage() throws JMSException
-    {
-        return new BytesMessageImpl(this, getConnectionImpl());
-    }
-
-    @Override
-    public MapMessage createMapMessage() throws JMSException
-    {
-        return new MapMessageImpl(this, getConnectionImpl());
-    }
-
-    @Override
-    public Message createMessage() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public ObjectMessage createObjectMessage() throws JMSException
-    {
-        return new ObjectMessageImpl(this, getConnectionImpl());
-    }
-
-    @Override
-    public ObjectMessage createObjectMessage(Serializable object) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public StreamMessage createStreamMessage() throws JMSException
-    {
-        return new StreamMessageImpl(this, getConnectionImpl());
-    }
-
-    @Override
-    public TextMessage createTextMessage() throws JMSException
-    {
-        return createTextMessage(null);
-    }
-
-    @Override
-    public TextMessage createTextMessage(String text) throws JMSException
-    {
-        TextMessage msg = new TextMessageImpl(this, _connectionImpl);
-        if(text != null)
-        {
-            msg.setText(text);
-        }
-
-        return msg;
-    }
-
-    @Override
-    public boolean getTransacted() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public int getAcknowledgeMode() throws JMSException
-    {
-        // TODO do we need to throw an exceptions (e.g. if closed)?
-        return _acknowledgeMode;
-    }
-
-    @Override
-    public void commit() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public void rollback() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public void recover() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public MessageListener getMessageListener() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public void setMessageListener(MessageListener listener) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public void run()
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public MessageConsumer createConsumer(Destination destination, String messageSelector) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public MessageConsumer createConsumer(Destination destination, String messageSelector, boolean NoLocal) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public Queue createQueue(String queueName) throws JMSException
-    {
-        return _destinationHelper.createQueue(queueName);
-    }
-
-    @Override
-    public Topic createTopic(String topicName) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public TopicSubscriber createDurableSubscriber(Topic topic, String name) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public TopicSubscriber createDurableSubscriber(Topic topic, String name, String messageSelector, boolean noLocal) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public QueueBrowser createBrowser(Queue queue) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public QueueBrowser createBrowser(Queue queue, String messageSelector) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public TemporaryQueue createTemporaryQueue() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public TemporaryTopic createTemporaryTopic() throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-
-    @Override
-    public void unsubscribe(String name) throws JMSException
-    {
-        // TODO Auto-generated method stub
-        throw new UnsupportedOperationException("Not Implemented");
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SimplePredicate.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SimplePredicate.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SimplePredicate.java
deleted file mode 100644
index 67fa346..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/SimplePredicate.java
+++ /dev/null
@@ -1,77 +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.jms.impl;
-
-import java.util.Arrays;
-
-
-abstract class SimplePredicate implements Predicate
-{
-    private final String _description;
-    private final Object[] _predicatedObjects;
-
-    public SimplePredicate()
-    {
-        this("");
-    }
-
-    /**
-     * @param description human-readable description. Useful for logging in case things go wrong.
-     * @param predicatedObject provided as a convenient way for toString() can hint at what is being predicated
-     */
-    public SimplePredicate(String description, Object... predicatedObjects)
-    {
-        _description = description;
-        _predicatedObjects = predicatedObjects;
-    }
-
-    @Override
-    public String getCurrentState()
-    {
-        StringBuilder builder = new StringBuilder("CurrentState [")
-            .append(this)
-            .append(getPredicatedObjects())
-            .append("]");
-        return builder.toString();
-    }
-
-    /**
-     * Returns the predicated objects as a list, or null if none exist
-     */
-    private Object getPredicatedObjects()
-    {
-        if(_predicatedObjects == null)
-        {
-            return null;
-        }
-        else
-        {
-            return Arrays.asList(_predicatedObjects);
-        }
-    }
-
-    @Override
-    public String toString()
-    {
-        StringBuilder builder = new StringBuilder(super.toString())
-            .append(" [_description=").append(_description)
-            .append("]");
-        return builder.toString();
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/StreamMessageImpl.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/StreamMessageImpl.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/StreamMessageImpl.java
deleted file mode 100644
index 2e01380..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/StreamMessageImpl.java
+++ /dev/null
@@ -1,525 +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.jms.impl;
-
-import java.util.Arrays;
-import java.util.HashSet;
-import java.util.Set;
-
-import javax.jms.Destination;
-import javax.jms.JMSException;
-import javax.jms.MessageEOFException;
-import javax.jms.MessageNotReadableException;
-import javax.jms.StreamMessage;
-
-import org.apache.qpid.jms.engine.AmqpListMessage;
-
-public class StreamMessageImpl extends MessageImpl<AmqpListMessage> implements StreamMessage
-{
-    private static final Set<Class<?>> SUPPORTED_TYPES =  new HashSet<Class<?>>(Arrays.asList(
-            Boolean.class, Byte.class, Short.class, Character.class, Integer.class, Long.class, Float.class, Double.class, String.class, byte[].class));
-
-    private static final int NO_BYTES_IN_FLIGHT = -1;
-    private int _remainingBytes = NO_BYTES_IN_FLIGHT;
-
-    //message to be sent
-    public StreamMessageImpl(SessionImpl sessionImpl, ConnectionImpl connectionImpl) throws JMSException
-    {
-        super(new AmqpListMessage(), sessionImpl, connectionImpl);
-    }
-
-    //message just received
-    public StreamMessageImpl(AmqpListMessage amqpMessage, SessionImpl sessionImpl, ConnectionImpl connectionImpl, Destination consumerDestination) throws JMSException
-    {
-        super(amqpMessage, sessionImpl, connectionImpl, consumerDestination);
-    }
-
-    @Override
-    protected AmqpListMessage prepareUnderlyingAmqpMessageForSending(AmqpListMessage amqpMessage)
-    {
-        //Currently nothing to do, we always operate directly on the underlying AmqpListMessage.
-        return amqpMessage;
-    }
-
-    private void checkObjectType(Object value) throws QpidJmsMessageFormatException
-    {
-        if(value != null && !SUPPORTED_TYPES.contains(value.getClass()))
-        {
-            throw new QpidJmsMessageFormatException("Invalid object value type: " + value.getClass());
-        }
-    }
-
-    void checkBodyReadable() throws MessageNotReadableException
-    {
-        if(isBodyWritable())
-        {
-            throw new MessageNotReadableException("Message body is currently in write-only mode");
-        }
-    }
-
-    private Object readObjectInternal(boolean checkExistingReadBytesUsage) throws MessageEOFException, QpidJmsMessageFormatException, MessageNotReadableException
-    {
-        checkBodyReadable();
-
-        if(checkExistingReadBytesUsage)
-        {
-            if(_remainingBytes != NO_BYTES_IN_FLIGHT)
-            {
-                throw new QpidJmsMessageFormatException("Partially read byte[] entry still being retrieved using readBytes(byte[] dest)");
-            }
-        }
-
-        try
-        {
-            return getUnderlyingAmqpMessage(false).get();
-        }
-        catch(IndexOutOfBoundsException ioobe)
-        {
-            throw new MessageEOFException("No more data in message stream");
-        }
-    }
-
-    private void decrementStreamPosition()
-    {
-        getUnderlyingAmqpMessage(false).decrementPosition();
-    }
-
-    //======= JMS Methods =======
-
-    @Override
-    public boolean readBoolean() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Boolean)
-        {
-            return (Boolean) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            return Boolean.valueOf((String)o);
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to boolean.");
-        }
-    }
-
-    @Override
-    public byte readByte() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Byte)
-        {
-            return (Byte) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            try
-            {
-                return Byte.valueOf((String)o);
-            }
-            catch(RuntimeException e)
-            {
-                decrementStreamPosition();
-                throw e;
-            }
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to byte.");
-        }
-    }
-
-    @Override
-    public short readShort() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Short)
-        {
-            return (Short) o;
-        }
-        else if(o instanceof Byte)
-        {
-            return (Byte) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            try
-            {
-                return Short.valueOf((String)o);
-            }
-            catch(RuntimeException e)
-            {
-                decrementStreamPosition();
-                throw e;
-            }
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to short.");
-        }
-    }
-
-    @Override
-    public char readChar() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Character)
-        {
-            return (Character) o;
-        }
-        else if(o == null)
-        {
-            decrementStreamPosition();
-            throw new NullPointerException("Stream entry with null value cannot be converted to char.");
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to char.");
-        }
-    }
-
-    @Override
-    public int readInt() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Integer)
-        {
-            return (Integer) o;
-        }
-        else if(o instanceof Short)
-        {
-            return (Short) o;
-        }
-        else if(o instanceof Byte)
-        {
-            return (Byte) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            try
-            {
-                return Integer.valueOf((String)o);
-            }
-            catch(RuntimeException e)
-            {
-                decrementStreamPosition();
-                throw e;
-            }
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to int.");
-        }
-    }
-
-    @Override
-    public long readLong() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Long)
-        {
-            return (Long) o;
-        }
-        else if(o instanceof Integer)
-        {
-            return (Integer) o;
-        }
-        else if(o instanceof Short)
-        {
-            return (Short) o;
-        }
-        else if(o instanceof Byte)
-        {
-            return (Byte) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            try
-            {
-                return Long.valueOf((String)o);
-            }
-            catch(RuntimeException e)
-            {
-                decrementStreamPosition();
-                throw e;
-            }
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to long.");
-        }
-    }
-
-    @Override
-    public float readFloat() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Float)
-        {
-            return (Float) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            try
-            {
-                return Float.valueOf((String)o);
-            }
-            catch(RuntimeException e)
-            {
-                decrementStreamPosition();
-                throw e;
-            }
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to float.");
-        }
-    }
-
-    @Override
-    public double readDouble() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof Float)
-        {
-            return (Float) o;
-        }
-        else if(o instanceof Double)
-        {
-            return (Double) o;
-        }
-        else if(o instanceof String || o == null)
-        {
-            try
-            {
-                return Double.valueOf((String)o);
-            }
-            catch(RuntimeException e)
-            {
-                decrementStreamPosition();
-                throw e;
-            }
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to double.");
-        }
-    }
-
-    @Override
-    public String readString() throws JMSException
-    {
-        Object o = readObject();
-        if(o instanceof String || o == null)
-        {
-            return (String) o;
-        }
-        else if(o instanceof byte[])
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to String.");
-        }
-        else
-        {
-            return String.valueOf(o);
-        }
-    }
-
-    @Override
-    public int readBytes(byte[] dest) throws JMSException
-    {
-        //TODO
-        Object o = readObjectInternal(false);
-
-        if(o == null)
-        {
-            return -1;
-        }
-
-        if(o instanceof byte[])
-        {
-            byte[] src = (byte[]) o;
-
-            if(src.length == 0)
-            {
-                return 0;
-            }
-
-            if(_remainingBytes == 0)
-            {
-                //We previously read all the bytes, but must have filled the dest array.
-                //Clear the remaining marker and signal completion via return value.
-                _remainingBytes = NO_BYTES_IN_FLIGHT;
-                return -1;
-            }
-
-            if(_remainingBytes == NO_BYTES_IN_FLIGHT)
-            {
-                //The field is non-null and non-empty, and this is the first read attempt.
-                //Set the remaining marker to the full size
-                _remainingBytes = src.length;
-            }
-
-            int previouslyRead = src.length - _remainingBytes;
-            int lengthToCopy = Math.min(dest.length, _remainingBytes);
-
-            if(lengthToCopy > 0)
-            {
-                System.arraycopy(src, previouslyRead, dest, 0, lengthToCopy);
-            }
-
-            _remainingBytes -= lengthToCopy;
-
-            if(_remainingBytes == 0 && lengthToCopy < dest.length)
-            {
-                //All bytes have been read and dest array was not filled on this call, so the return
-                //will enable the caller to determine completion. Clear the remaining marker.
-                _remainingBytes = NO_BYTES_IN_FLIGHT;
-            }
-            else
-            {
-                decrementStreamPosition();
-            }
-
-            return lengthToCopy;
-        }
-        else
-        {
-            decrementStreamPosition();
-            throw new QpidJmsMessageFormatException("Stream entry of type " + o.getClass().getName() + " cannot be converted to bytes.");
-        }
-    }
-
-    @Override
-    public Object readObject() throws JMSException
-    {
-        return readObjectInternal(true);
-    }
-
-    @Override
-    public void writeBoolean(boolean value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeByte(byte value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeShort(short value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeChar(char value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeInt(int value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeLong(long value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeFloat(float value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeDouble(double value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeString(String value) throws JMSException
-    {
-        writeObject(value);
-    }
-
-    @Override
-    public void writeBytes(byte[] value) throws JMSException
-    {
-        writeBytes(value, 0, value.length);
-    }
-
-    @Override
-    public void writeBytes(byte[] value, int offset, int length) throws JMSException
-    {
-        checkBodyWritable();
-
-        byte[] dest = new byte[length];
-        System.arraycopy(value, offset, dest, 0, length);
-
-        getUnderlyingAmqpMessage(false).add(dest);
-    }
-
-    @Override
-    public void writeObject(Object value) throws JMSException
-    {
-        if(value instanceof byte[])
-        {
-            writeBytes((byte[]) value);
-            return;
-        }
-
-        checkBodyWritable();
-        checkObjectType(value);
-
-        getUnderlyingAmqpMessage(false).add(value);
-    }
-
-    @Override
-    public void reset() throws JMSException
-    {
-        getUnderlyingAmqpMessage(false).resetPosition();
-        setBodyWritable(false);
-        _remainingBytes = -1;
-    }
-
-    @Override
-    public void clearBody() throws JMSException
-    {
-        getUnderlyingAmqpMessage(false).clear();
-        setBodyWritable(true);
-        _remainingBytes = -1;
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TextMessageImpl.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TextMessageImpl.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TextMessageImpl.java
deleted file mode 100644
index bba3ade..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TextMessageImpl.java
+++ /dev/null
@@ -1,75 +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.jms.impl;
-
-import javax.jms.Destination;
-import javax.jms.JMSException;
-import javax.jms.TextMessage;
-
-import org.apache.qpid.jms.engine.AmqpTextMessage;
-
-public class TextMessageImpl extends MessageImpl<AmqpTextMessage> implements TextMessage
-{
-    //message to be sent
-    public TextMessageImpl(SessionImpl sessionImpl, ConnectionImpl connectionImpl) throws JMSException
-    {
-        super(new AmqpTextMessage(), sessionImpl, connectionImpl);
-    }
-
-    //message just received
-    public TextMessageImpl(AmqpTextMessage amqpMessage, SessionImpl sessionImpl, ConnectionImpl connectionImpl, Destination consumerDestination) throws JMSException
-    {
-        super(amqpMessage, sessionImpl, connectionImpl, consumerDestination);
-    }
-
-    @Override
-    protected AmqpTextMessage prepareUnderlyingAmqpMessageForSending(AmqpTextMessage amqpMessage)
-    {
-        //Nothing to do here currently, the message operations are all
-        //already operating on the AmqpTextMessage directly
-        return amqpMessage;
-    }
-
-    //======= JMS Methods =======
-
-    @Override
-    public String getText() throws JMSException
-    {
-        return getUnderlyingAmqpMessage(false).getText();
-    }
-
-    @Override
-    public void setText(String text) throws JMSException
-    {
-        checkBodyWritable();
-
-        getUnderlyingAmqpMessage(false).setText(text);
-    }
-
-    @Override
-    public void clearBody() throws JMSException
-    {
-        AmqpTextMessage underlyingAmqpMessage = getUnderlyingAmqpMessage(false);
-        underlyingAmqpMessage.setText(null);
-
-        underlyingAmqpMessage.setContentType(null);
-
-        setBodyWritable(true);
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TopicImpl.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TopicImpl.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TopicImpl.java
deleted file mode 100644
index 9f1bd10..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/TopicImpl.java
+++ /dev/null
@@ -1,39 +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.jms.impl;
-
-import javax.jms.JMSException;
-import javax.jms.Topic;
-
-public class TopicImpl extends DestinationImpl implements Topic
-{
-    public TopicImpl(String topicName)
-    {
-        super(topicName);
-    }
-
-    @Override
-    public String getTopicName() throws JMSException
-    {
-        return getAddress();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Drain.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Drain.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Drain.java
deleted file mode 100644
index df54449..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Drain.java
+++ /dev/null
@@ -1,129 +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.jms.impl.temp;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.jms.Connection;
-import javax.jms.Destination;
-import javax.jms.MessageConsumer;
-import javax.jms.Session;
-import javax.jms.TextMessage;
-
-import org.apache.qpid.jms.impl.ConnectionImpl;
-
-public class Drain
-{
-    private static final String DEFAULT_USER = "guest";
-    private static final String DEFAULT_PASSWORD = "guest";
-    private static final int DEFAULT_PORT = 5672;
-    private static final String DEFAULT_HOST = "localhost";
-    private static final int DEFAULT_COUNT = 10000;
-
-    private String _hostname;
-    private int _port;
-    private int _count;
-    private String _username;
-    private String _password;
-
-    public Drain(int count, String hostname, int port)
-    {
-        _count = count;
-        _hostname = hostname;
-        _port = port;
-        _username = DEFAULT_USER;
-        _password = DEFAULT_PASSWORD;
-    }
-
-    public void runTest()
-    {
-        try
-        {
-            Connection connection = new ConnectionImpl("drain", _hostname, _port, _username, _password);
-            connection.start();
-
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-
-            Destination queue = session.createQueue("myQueue");
-            MessageConsumer messageConsumer = session.createConsumer(queue);
-
-            long start = System.currentTimeMillis();
-
-            int actualCount = 0;
-            boolean deductTimeout = false;
-            int timeout = 1000;
-            for(int i = 1; i <= _count; i++, actualCount++)
-            {
-                TextMessage message = (TextMessage)messageConsumer.receive(timeout);
-                if(message == null)
-                {
-                    System.out.println("Message not received, stopping");
-                    deductTimeout = true;
-                    break;
-                }
-                if(i % 100 == 0)
-                {
-                    System.out.println("Got message " + i + ":" + message.getText());
-                }
-            }
-
-            long finish = System.currentTimeMillis();
-            long taken = finish - start;
-            if(deductTimeout)
-            {
-                taken -= timeout;
-            }
-            System.out.println("Received " + actualCount +" messages in " + taken + "ms");
-
-            connection.close();
-            System.exit(0);//TODO: remove
-        }
-        catch (Exception exp)
-        {
-            exp.printStackTrace();
-            System.exit(1);
-        }
-    }
-
-    public static void main(String[] argv) throws Exception
-    {
-        List<String> switches = new ArrayList<String>();
-        List<String> args = new ArrayList<String>();
-        for (String s : argv)
-        {
-            if (s.startsWith("-"))
-            {
-                switches.add(s);
-            }
-            else
-            {
-                args.add(s);
-            }
-        }
-
-        int count = args.isEmpty() ? DEFAULT_COUNT : Integer.parseInt(args.remove(0));
-        String hostname = args.isEmpty() ? DEFAULT_HOST : args.remove(0);
-        int port = args.isEmpty() ? DEFAULT_PORT : Integer.parseInt(args.remove(0));
-
-        new Drain(count, hostname, port).runTest();
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Spout.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Spout.java b/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Spout.java
deleted file mode 100644
index 2e22506..0000000
--- a/qpid-jms-client-tmp/src/main/java/org/apache/qpid/jms/impl/temp/Spout.java
+++ /dev/null
@@ -1,122 +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.jms.impl.temp;
-
-import java.util.ArrayList;
-import java.util.List;
-
-import javax.jms.Connection;
-import javax.jms.DeliveryMode;
-import javax.jms.Destination;
-import javax.jms.Message;
-import javax.jms.MessageProducer;
-import javax.jms.Session;
-import javax.jms.TextMessage;
-
-import org.apache.qpid.jms.impl.ConnectionImpl;
-
-public class Spout
-{
-    private static final String DEFAULT_USER = "guest";
-    private static final String DEFAULT_PASSWORD = "guest";
-    private static final int DEFAULT_PORT = 5672;
-    private static final String DEFAULT_HOST = "localhost";
-    private static final int DEFAULT_COUNT = 10000;
-
-    private String _hostname;
-    private int _port;
-    private int _count;
-    private String _username;
-    private String _password;
-    private boolean _persistent;
-
-    public Spout(int count, String hostname, int port, boolean persistent)
-    {
-        _count = count;
-        _hostname = hostname;
-        _port = port;
-        _persistent = persistent;
-        _username = DEFAULT_USER;
-        _password = DEFAULT_PASSWORD;
-    }
-
-    public void runTest()
-    {
-        try
-        {
-            Connection connection = new ConnectionImpl("spout", _hostname, _port, _username, _password);
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-
-            Destination queue = session.createQueue("myQueue");
-            MessageProducer messageProducer = session.createProducer(queue);
-
-            int dekiveryMode = _persistent ? DeliveryMode.PERSISTENT : DeliveryMode.NON_PERSISTENT;
-
-            long start = System.currentTimeMillis();
-            for(int i = 1; i <= _count; i++)
-            {
-                TextMessage message = session.createTextMessage("Hello world!");
-                messageProducer.send(message, dekiveryMode, Message.DEFAULT_PRIORITY, Message.DEFAULT_TIME_TO_LIVE);
-
-                if(i % 100 == 0)
-                {
-                    System.out.println("Sent message " + i + ":" + message.getText());
-                }
-            }
-
-            long finish = System.currentTimeMillis();
-            long taken = finish - start;
-            System.out.println("Sent " + _count +" messages in " + taken + "ms");
-
-            connection.close();
-            System.exit(0);//TODO: remove
-        }
-        catch (Exception exp)
-        {
-            exp.printStackTrace();
-            System.exit(1);
-        }
-    }
-
-    public static void main(String[] argv) throws Exception
-    {
-        List<String> switches = new ArrayList<String>();
-        List<String> args = new ArrayList<String>();
-        for (String s : argv)
-        {
-            if (s.startsWith("-"))
-            {
-                switches.add(s);
-            }
-            else
-            {
-                args.add(s);
-            }
-        }
-
-        int count = args.isEmpty() ? DEFAULT_COUNT : Integer.parseInt(args.remove(0));
-        String hostname = args.isEmpty() ? DEFAULT_HOST : args.remove(0);
-        int port = args.isEmpty() ? DEFAULT_PORT : Integer.parseInt(args.remove(0));
-        boolean persistent = switches.contains("-p");
-
-        new Spout(count, hostname, port, persistent).runTest();
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/site/findbugs.xml
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/site/findbugs.xml b/qpid-jms-client-tmp/src/site/findbugs.xml
deleted file mode 100644
index c4db2c7..0000000
--- a/qpid-jms-client-tmp/src/site/findbugs.xml
+++ /dev/null
@@ -1,267 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
- -
- - 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.
- -
- -->
-<!-- Generated by Sonar -->
-<FindBugsFilter>
-  <Match>
-    <Bug pattern="SE_NO_SUITABLE_CONSTRUCTOR"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_NO_SUITABLE_CONSTRUCTOR_FOR_EXTERNALIZATION"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_NO_SERIALVERSIONID"/>
-  </Match>
-  <Match>
-    <Bug pattern="NP_TOSTRING_COULD_RETURN_NULL"/>
-  </Match>
-  <Match>
-    <Bug pattern="NP_GUARANTEED_DEREF"/>
-  </Match>
-  <Match>
-    <Bug pattern="OS_OPEN_STREAM"/>
-  </Match>
-  <Match>
-    <Bug pattern="OS_OPEN_STREAM_EXCEPTION_PATH"/>
-  </Match>
-  <Match>
-    <Bug pattern="UL_UNRELEASED_LOCK"/>
-  </Match>
-  <Match>
-    <Bug pattern="UL_UNRELEASED_LOCK_EXCEPTION_PATH"/>
-  </Match>
-  <Match>
-    <Bug pattern="RC_REF_COMPARISON"/>
-  </Match>
-  <Match>
-    <Bug pattern="VA_FORMAT_STRING_BAD_ARGUMENT"/>
-  </Match>
-  <Match>
-    <Bug pattern="VA_FORMAT_STRING_MISSING_ARGUMENT"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_NONFINAL_SERIALVERSIONID"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_NONSTATIC_SERIALVERSIONID"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_NONLONG_SERIALVERSIONID"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_BAD_FIELD_INNER_CLASS"/>
-  </Match>
-  <Match>
-    <Bug pattern="SE_BAD_FIELD_STORE"/>
-  </Match>
-  <Match>
-    <Bug pattern="SIC_INNER_SHOULD_BE_STATIC_ANON"/>
-  </Match>
-  <Match>
-    <Bug pattern="ES_COMPARING_STRINGS_WITH_EQ"/>
-  </Match>
-  <Match>
-    <Bug pattern="ES_COMPARING_PARAMETER_STRING_WITH_EQ"/>
-  </Match>
-  <Match>
-    <Bug pattern="HE_USE_OF_UNHASHABLE_CLASS"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_COMPARETO_USE_OBJECT_EQUALS"/>
-  </Match>
-  <Match>
-    <Bug pattern="HE_HASHCODE_USE_OBJECT_EQUALS"/>
-  </Match>
-  <Match>
-    <Bug pattern="HE_HASHCODE_NO_EQUALS"/>
-  </Match>
-  <Match>
-    <Bug pattern="HE_EQUALS_USE_HASHCODE"/>
-  </Match>
-  <Match>
-    <Bug pattern="HE_INHERITS_EQUALS_USE_HASHCODE"/>
-  </Match>
-  <Match>
-    <Bug pattern="HE_EQUALS_NO_HASHCODE"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_ABSTRACT_SELF"/>
-  </Match>
-  <Match>
-    <Bug pattern="CO_ABSTRACT_SELF"/>
-  </Match>
-  <Match>
-    <Bug pattern="DL_SYNCHRONIZATION_ON_BOOLEAN"/>
-  </Match>
-  <Match>
-    <Bug pattern="DL_SYNCHRONIZATION_ON_BOXED_PRIMITIVE"/>
-  </Match>
-  <Match>
-    <Bug pattern="DL_SYNCHRONIZATION_ON_UNSHARED_BOXED_PRIMITIVE"/>
-  </Match>
-  <Match>
-    <Bug pattern="WL_USING_GETCLASS_RATHER_THAN_CLASS_LITERAL"/>
-  </Match>
-  <Match>
-    <Bug pattern="RU_INVOKE_RUN"/>
-  </Match>
-  <Match>
-    <Bug pattern="NS_DANGEROUS_NON_SHORT_CIRCUIT"/>
-  </Match>
-  <Match>
-    <Bug pattern="IS_FIELD_NOT_GUARDED"/>
-  </Match>
-  <Match>
-    <Bug pattern="ML_SYNC_ON_FIELD_TO_GUARD_CHANGING_THAT_FIELD"/>
-  </Match>
-  <Match>
-    <Bug pattern="SA_FIELD_SELF_ASSIGNMENT"/>
-  </Match>
-  <Match>
-    <Bug pattern="SA_LOCAL_DOUBLE_ASSIGNMENT"/>
-  </Match>
-  <Match>
-    <Bug pattern="SA_FIELD_DOUBLE_ASSIGNMENT"/>
-  </Match>
-  <Match>
-    <Bug pattern="SA_FIELD_SELF_COMPARISON"/>
-  </Match>
-  <Match>
-    <Bug pattern="UPM_UNCALLED_PRIVATE_METHOD"/>
-  </Match>
-  <Match>
-    <Bug pattern="ODR_OPEN_DATABASE_RESOURCE"/>
-  </Match>
-  <Match>
-    <Bug pattern="ODR_OPEN_DATABASE_RESOURCE_EXCEPTION_PATH"/>
-  </Match>
-  <Match>
-    <Bug pattern="SBSC_USE_STRINGBUFFER_CONCATENATION"/>
-  </Match>
-  <Match>
-    <Bug pattern="EC_BAD_ARRAY_COMPARE"/>
-  </Match>
-  <Match>
-    <Bug pattern="HSC_HUGE_SHARED_STRING_CONSTANT"/>
-  </Match>
-  <Match>
-    <Bug pattern="RpC_REPEATED_CONDITIONAL_TEST"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_EXIT"/>
-  </Match>
-  <Match>
-    <Bug pattern="DMI_EMPTY_DB_PASSWORD"/>
-  </Match>
-  <Match>
-    <Bug pattern="DMI_UNSUPPORTED_METHOD"/>
-  </Match>
-  <Match>
-    <Bug pattern="DMI_BLOCKING_METHODS_ON_URL"/>
-  </Match>
-  <Match>
-    <Bug pattern="DMI_COLLECTION_OF_URLS"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_RUN_FINALIZERS_ON_EXIT"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_STRING_VOID_CTOR"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_GC"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_BOOLEAN_CTOR"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_NUMBER_CTOR"/>
-  </Match>
-  <Match>
-    <Bug pattern="NP_EQUALS_SHOULD_HANDLE_NULL_ARGUMENT"/>
-  </Match>
-  <Match>
-    <Bug pattern="HRS_REQUEST_PARAMETER_TO_COOKIE"/>
-  </Match>
-  <Match>
-    <Bug pattern="STCAL_STATIC_CALENDAR_INSTANCE"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_COMPARING_CLASS_NAMES"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_ALWAYS_TRUE"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_ALWAYS_FALSE"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_DONT_DEFINE_EQUALS_FOR_ENUM"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_SELF_USE_OBJECT"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_OTHER_USE_OBJECT"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_OTHER_NO_OBJECT"/>
-  </Match>
-  <Match>
-    <Bug pattern="EQ_SELF_NO_OBJECT"/>
-  </Match>
-  <Match>
-    <Bug pattern="CO_SELF_NO_OBJECT"/>
-  </Match>
-  <Match>
-    <Bug pattern="RE_CANT_USE_FILE_SEPARATOR_AS_REGULAR_EXPRESSION"/>
-  </Match>
-  <Match>
-    <Bug pattern="IM_BAD_CHECK_FOR_ODD"/>
-  </Match>
-  <Match>
-    <Bug pattern="DMI_HARDCODED_ABSOLUTE_FILENAME"/>
-  </Match>
-  <Match>
-    <Bug pattern="SWL_SLEEP_WITH_LOCK_HELD"/>
-  </Match>
-  <Match>
-    <Bug pattern="NP_NULL_INSTANCEOF"/>
-  </Match>
-  <Match>
-    <Bug pattern="BC_EQUALS_METHOD_SHOULD_WORK_FOR_ALL_OBJECTS"/>
-  </Match>
-  <Match>
-    <Bug pattern="BC_IMPOSSIBLE_CAST"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_BOXED_PRIMITIVE_TOSTRING"/>
-  </Match>
-  <Match>
-    <Bug pattern="STCAL_STATIC_SIMPLE_DATE_FORMAT_INSTANCE"/>
-  </Match>
-  <Match>
-    <Bug pattern="DMI_CONSTANT_DB_PASSWORD"/>
-  </Match>
-  <Match>
-    <Bug pattern="DM_CONVERT_CASE"/>
-  </Match>
-</FindBugsFilter>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/BytesMessageIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/BytesMessageIntegrationTest.java b/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/BytesMessageIntegrationTest.java
deleted file mode 100644
index e47a153..0000000
--- a/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/BytesMessageIntegrationTest.java
+++ /dev/null
@@ -1,350 +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.jms;
-
-import static org.hamcrest.Matchers.equalTo;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-import java.io.ByteArrayOutputStream;
-import java.io.DataOutputStream;
-import java.util.Arrays;
-
-import javax.jms.BytesMessage;
-import javax.jms.Connection;
-import javax.jms.Message;
-import javax.jms.MessageConsumer;
-import javax.jms.MessageProducer;
-import javax.jms.Queue;
-import javax.jms.Session;
-
-import org.apache.qpid.jms.engine.AmqpBytesMessage;
-import org.apache.qpid.jms.impl.ClientProperties;
-import org.apache.qpid.jms.test.testpeer.TestAmqpPeer;
-import org.apache.qpid.jms.test.testpeer.describedtypes.sections.AmqpValueDescribedType;
-import org.apache.qpid.jms.test.testpeer.describedtypes.sections.DataDescribedType;
-import org.apache.qpid.jms.test.testpeer.describedtypes.sections.MessageAnnotationsDescribedType;
-import org.apache.qpid.jms.test.testpeer.describedtypes.sections.PropertiesDescribedType;
-import org.apache.qpid.jms.test.testpeer.matchers.sections.MessageAnnotationsSectionMatcher;
-import org.apache.qpid.jms.test.testpeer.matchers.sections.MessageHeaderSectionMatcher;
-import org.apache.qpid.jms.test.testpeer.matchers.sections.MessagePropertiesSectionMatcher;
-import org.apache.qpid.jms.test.testpeer.matchers.sections.TransferPayloadCompositeMatcher;
-import org.apache.qpid.jms.test.testpeer.matchers.types.EncodedDataMatcher;
-import org.apache.qpid.proton.amqp.Binary;
-import org.apache.qpid.proton.amqp.DescribedType;
-import org.apache.qpid.proton.amqp.Symbol;
-import org.junit.Test;
-
-public class BytesMessageIntegrationTest extends QpidJmsTestCase
-{
-    private final IntegrationTestFixture _testFixture = new IntegrationTestFixture();
-
-    @Test
-    public void testSendBasicBytesMessageWithContent() throws Exception
-    {
-        try(TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);)
-        {
-            Connection connection = _testFixture.establishConnecton(testPeer);
-            testPeer.expectBegin(true);
-            testPeer.expectSenderAttach();
-
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-            Queue queue = session.createQueue("myQueue");
-            MessageProducer producer = session.createProducer(queue);
-
-            byte[] content = "myBytes".getBytes();
-
-            MessageHeaderSectionMatcher headersMatcher = new MessageHeaderSectionMatcher(true).withDurable(equalTo(true));
-            MessageAnnotationsSectionMatcher msgAnnotationsMatcher = new MessageAnnotationsSectionMatcher(true);
-            msgAnnotationsMatcher.withEntry(Symbol.valueOf(ClientProperties.X_OPT_JMS_MSG_TYPE), equalTo(ClientProperties.BYTES_MESSAGE_TYPE));
-            MessagePropertiesSectionMatcher propertiesMatcher = new MessagePropertiesSectionMatcher(true);
-            propertiesMatcher.withContentType(equalTo(Symbol.valueOf(AmqpBytesMessage.CONTENT_TYPE)));
-            TransferPayloadCompositeMatcher messageMatcher = new TransferPayloadCompositeMatcher();
-            messageMatcher.setHeadersMatcher(headersMatcher);
-            messageMatcher.setMessageAnnotationsMatcher(msgAnnotationsMatcher);
-            messageMatcher.setPropertiesMatcher(propertiesMatcher);
-            messageMatcher.setMessageContentMatcher(new EncodedDataMatcher(new Binary(content)));
-
-            testPeer.expectTransfer(messageMatcher);
-
-            BytesMessage message = session.createBytesMessage();
-            message.writeBytes(content);
-
-            producer.send(message);
-        }
-    }
-
-    @Test
-    public void testReceiveBasicBytesMessageWithContentUsingDataSection() throws Exception
-    {
-        try(TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);)
-        {
-            Connection connection = _testFixture.establishConnecton(testPeer);
-            connection.start();
-
-            testPeer.expectBegin(true);
-
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-            Queue queue = session.createQueue("myQueue");
-
-            PropertiesDescribedType properties = new PropertiesDescribedType();
-            properties.setContentType(Symbol.valueOf(AmqpBytesMessage.CONTENT_TYPE));
-
-            MessageAnnotationsDescribedType msgAnnotations = new MessageAnnotationsDescribedType();
-            msgAnnotations.setSymbolKeyedAnnotation(ClientProperties.X_OPT_JMS_MSG_TYPE, ClientProperties.BYTES_MESSAGE_TYPE);
-
-            final byte[] expectedContent = "expectedContent".getBytes();
-            DescribedType dataContent = new DataDescribedType(new Binary(expectedContent));
-
-            testPeer.expectReceiverAttach();
-            testPeer.expectLinkFlowRespondWithTransfer(null, msgAnnotations, properties, null, dataContent);
-            testPeer.expectDispositionThatIsAcceptedAndSettled();
-
-            MessageConsumer messageConsumer = session.createConsumer(queue);
-            Message receivedMessage = messageConsumer.receive(1000);
-            testPeer.waitForAllHandlersToComplete(3000);
-
-            assertNotNull(receivedMessage);
-            assertTrue(receivedMessage instanceof BytesMessage);
-            BytesMessage bytesMessage = (BytesMessage)receivedMessage;
-            assertEquals(expectedContent.length, bytesMessage.getBodyLength());
-            byte[] recievedContent = new byte[expectedContent.length];
-            int readBytes = bytesMessage.readBytes(recievedContent);
-            assertEquals(recievedContent.length, readBytes);
-            assertTrue(Arrays.equals(expectedContent, recievedContent));
-        }
-    }
-
-    /**
-     * Test that a message received from the test peer with a Data section and content type of
-     * {@link AmqpBytesMessage#CONTENT_TYPE} is returned as a BytesMessage, verify it gives
-     * the expected data values when read, and when reset and left mid-stream before being
-     * resent that it results in the expected AMQP data body section and properties content type
-     * being received by the test peer.
-     */
-    @Test
-    public void testReceiveBytesMessageAndResendAfterResetAndPartialRead() throws Exception
-    {
-        try(TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);)
-        {
-            Connection connection = _testFixture.establishConnecton(testPeer);
-            connection.start();
-
-            testPeer.expectBegin(true);
-
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-            Queue queue = session.createQueue("myQueue");
-
-            //Prepare an AMQP message for the test peer to send, containing the content type and
-            //a data body section populated with expected bytes for use as a JMS BytesMessage 
-            PropertiesDescribedType properties = new PropertiesDescribedType();
-            Symbol contentType = Symbol.valueOf(AmqpBytesMessage.CONTENT_TYPE);
-            properties.setContentType(contentType);
-
-            MessageAnnotationsDescribedType msgAnnotations = new MessageAnnotationsDescribedType();
-            msgAnnotations.setSymbolKeyedAnnotation(ClientProperties.X_OPT_JMS_MSG_TYPE, ClientProperties.BYTES_MESSAGE_TYPE);
-
-            boolean myBool = true;
-            byte myByte = 4;
-            byte[] myBytes = "myBytes".getBytes();
-            char myChar = 'd';
-            double myDouble = 1234567890123456789.1234;
-            float myFloat = 1.1F;
-            int myInt = Integer.MAX_VALUE;
-            long myLong = Long.MAX_VALUE;
-            short myShort = 25;
-            String myUTF = "myString";
-
-            ByteArrayOutputStream baos = new ByteArrayOutputStream();
-            DataOutputStream dos = new DataOutputStream(baos);
-
-            dos.writeBoolean(myBool);
-            dos.writeByte(myByte);
-            dos.write(myBytes);
-            dos.writeChar(myChar);
-            dos.writeDouble(myDouble);
-            dos.writeFloat(myFloat);
-            dos.writeInt(myInt);
-            dos.writeLong(myLong);
-            dos.writeShort(myShort);
-            dos.writeUTF(myUTF);
-
-            byte[] bytesPayload = baos.toByteArray();
-            Binary binaryPayload = new Binary(bytesPayload);
-            DescribedType dataSectionContent = new DataDescribedType(binaryPayload);
-
-            //receive the message from the test peer
-            testPeer.expectReceiverAttach();
-            testPeer.expectLinkFlowRespondWithTransfer(null, msgAnnotations, properties, null, dataSectionContent);
-            testPeer.expectDispositionThatIsAcceptedAndSettled();
-
-            MessageConsumer messageConsumer = session.createConsumer(queue);
-            Message receivedMessage = messageConsumer.receive(1000);
-            testPeer.waitForAllHandlersToComplete(3000);
-
-            //verify the content is as expected
-            assertNotNull("Message was not received", receivedMessage);
-            assertTrue("Message was not a BytesMessage", receivedMessage instanceof BytesMessage);
-            BytesMessage receivedBytesMessage  = (BytesMessage) receivedMessage;
-
-            assertEquals("Unexpected boolean value", myBool, receivedBytesMessage.readBoolean());
-            assertEquals("Unexpected byte value", myByte, receivedBytesMessage.readByte());
-            byte[] readBytes = new byte[myBytes.length];
-            assertEquals("Did not read the expected number of bytes", myBytes.length, receivedBytesMessage.readBytes(readBytes));
-            assertTrue("Read bytes were not as expected: " + Arrays.toString(readBytes), Arrays.equals(myBytes, readBytes));
-            assertEquals("Unexpected char value", myChar, receivedBytesMessage.readChar());
-            assertEquals("Unexpected double value", myDouble, receivedBytesMessage.readDouble(), 0.0);
-            assertEquals("Unexpected float value", myFloat, receivedBytesMessage.readFloat(), 0.0);
-            assertEquals("Unexpected int value", myInt, receivedBytesMessage.readInt());
-            assertEquals("Unexpected long value", myLong, receivedBytesMessage.readLong());
-            assertEquals("Unexpected short value", myShort, receivedBytesMessage.readShort());
-            assertEquals("Unexpected UTF value", myUTF, receivedBytesMessage.readUTF());
-
-            //reset and read the first item, leaving message marker in the middle of its content
-            receivedBytesMessage.reset();
-            assertEquals("Unexpected boolean value after reset", myBool, receivedBytesMessage.readBoolean());
-
-            //Send the received message back to the test peer and have it check the result is as expected
-            testPeer.expectSenderAttach();
-            MessageProducer producer = session.createProducer(queue);
-
-            MessageHeaderSectionMatcher headersMatcher = new MessageHeaderSectionMatcher(true);
-            MessageAnnotationsSectionMatcher msgAnnotationsMatcher = new MessageAnnotationsSectionMatcher(true);
-            MessagePropertiesSectionMatcher propsMatcher = new MessagePropertiesSectionMatcher(true);
-            propsMatcher.withContentType(equalTo(contentType));
-            TransferPayloadCompositeMatcher messageMatcher = new TransferPayloadCompositeMatcher();
-            messageMatcher.setHeadersMatcher(headersMatcher);
-            messageMatcher.setMessageAnnotationsMatcher(msgAnnotationsMatcher);
-            messageMatcher.setPropertiesMatcher(propsMatcher);
-            messageMatcher.setMessageContentMatcher(new EncodedDataMatcher(binaryPayload));
-            testPeer.expectTransfer(messageMatcher);
-
-            producer.send(receivedBytesMessage);
-
-            testPeer.waitForAllHandlersToComplete(3000);
-        }
-    }
-
-    /**
-     * Test that a message received from the test peer with an AmqpValue section containing Binary
-     * and no content type is returned as a BytesMessage, verify it gives the
-     * expected data values when read, and when sent to the test peer it results in an
-     * AMQP message containing a data body section and content type of {@link AmqpBytesMessage#CONTENT_TYPE}
-     */
-    @Test
-    public void testReceiveBytesMessageWithAmqpValueAndResendResultsInData() throws Exception
-    {
-        try(TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);)
-        {
-            Connection connection = _testFixture.establishConnecton(testPeer);
-            connection.start();
-
-            testPeer.expectBegin(true);
-
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-            Queue queue = session.createQueue("myQueue");
-
-            //Prepare an AMQP message for the test peer to send, containing an amqp-value
-            //body section populated with expected bytes for use as a JMS BytesMessage,
-            //and do not set content type, or the message type annotation
-
-            boolean myBool = true;
-            byte myByte = 4;
-            byte[] myBytes = "myBytes".getBytes();
-            char myChar = 'd';
-            double myDouble = 1234567890123456789.1234;
-            float myFloat = 1.1F;
-            int myInt = Integer.MAX_VALUE;
-            long myLong = Long.MAX_VALUE;
-            short myShort = 25;
-            String myUTF = "myString";
-
-            ByteArrayOutputStream baos = new ByteArrayOutputStream();
-            DataOutputStream dos = new DataOutputStream(baos);
-
-            dos.writeBoolean(myBool);
-            dos.writeByte(myByte);
-            dos.write(myBytes);
-            dos.writeChar(myChar);
-            dos.writeDouble(myDouble);
-            dos.writeFloat(myFloat);
-            dos.writeInt(myInt);
-            dos.writeLong(myLong);
-            dos.writeShort(myShort);
-            dos.writeUTF(myUTF);
-
-            byte[] bytesPayload = baos.toByteArray();
-            Binary binaryPayload = new Binary(bytesPayload);
-
-            DescribedType amqpValueSectionContent = new AmqpValueDescribedType(binaryPayload);
-
-            //receive the message from the test peer
-            testPeer.expectReceiverAttach();
-            testPeer.expectLinkFlowRespondWithTransfer(null, null, null, null, amqpValueSectionContent);
-            testPeer.expectDispositionThatIsAcceptedAndSettled();
-
-            MessageConsumer messageConsumer = session.createConsumer(queue);
-            Message receivedMessage = messageConsumer.receive(1000);
-            testPeer.waitForAllHandlersToComplete(3000);
-
-            //verify the content is as expected
-            assertNotNull("Message was not received", receivedMessage);
-            assertTrue("Message was not a BytesMessage", receivedMessage instanceof BytesMessage);
-            BytesMessage receivedBytesMessage  = (BytesMessage) receivedMessage;
-
-            assertEquals("Unexpected boolean value", myBool, receivedBytesMessage.readBoolean());
-            assertEquals("Unexpected byte value", myByte, receivedBytesMessage.readByte());
-            byte[] readBytes = new byte[myBytes.length];
-            assertEquals("Did not read the expected number of bytes", myBytes.length, receivedBytesMessage.readBytes(readBytes));
-            assertTrue("Read bytes were not as expected: " + Arrays.toString(readBytes), Arrays.equals(myBytes, readBytes));
-            assertEquals("Unexpected char value", myChar, receivedBytesMessage.readChar());
-            assertEquals("Unexpected double value", myDouble, receivedBytesMessage.readDouble(), 0.0);
-            assertEquals("Unexpected float value", myFloat, receivedBytesMessage.readFloat(), 0.0);
-            assertEquals("Unexpected int value", myInt, receivedBytesMessage.readInt());
-            assertEquals("Unexpected long value", myLong, receivedBytesMessage.readLong());
-            assertEquals("Unexpected short value", myShort, receivedBytesMessage.readShort());
-            assertEquals("Unexpected UTF value", myUTF, receivedBytesMessage.readUTF());
-
-            //reset and read the first item, leaving message marker in the middle of its content
-            receivedBytesMessage.reset();
-            assertEquals("Unexpected boolean value after reset", myBool, receivedBytesMessage.readBoolean());
-
-            //Send the received message back to the test peer and have it check the result is as expected
-            testPeer.expectSenderAttach();
-            MessageProducer producer = session.createProducer(queue);
-
-            MessageHeaderSectionMatcher headersMatcher = new MessageHeaderSectionMatcher(true);
-            MessageAnnotationsSectionMatcher msgAnnotationsMatcher = new MessageAnnotationsSectionMatcher(true);
-            msgAnnotationsMatcher.withEntry(Symbol.valueOf(ClientProperties.X_OPT_JMS_MSG_TYPE), equalTo(ClientProperties.BYTES_MESSAGE_TYPE));
-            MessagePropertiesSectionMatcher propsMatcher = new MessagePropertiesSectionMatcher(true);
-            propsMatcher.withContentType(equalTo(Symbol.valueOf(AmqpBytesMessage.CONTENT_TYPE)));
-            TransferPayloadCompositeMatcher messageMatcher = new TransferPayloadCompositeMatcher();
-            messageMatcher.setHeadersMatcher(headersMatcher);
-            messageMatcher.setMessageAnnotationsMatcher(msgAnnotationsMatcher);
-            messageMatcher.setPropertiesMatcher(propsMatcher);
-            messageMatcher.setMessageContentMatcher(new EncodedDataMatcher(binaryPayload));
-            testPeer.expectTransfer(messageMatcher);
-
-            producer.send(receivedBytesMessage);
-
-            testPeer.waitForAllHandlersToComplete(3000);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/ConnectionIntegrationTest.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/ConnectionIntegrationTest.java b/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/ConnectionIntegrationTest.java
deleted file mode 100644
index c37dde7..0000000
--- a/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/ConnectionIntegrationTest.java
+++ /dev/null
@@ -1,58 +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.jms;
-
-import static org.junit.Assert.assertNotNull;
-
-import javax.jms.Connection;
-import javax.jms.Session;
-
-import org.apache.qpid.jms.test.testpeer.TestAmqpPeer;
-import org.junit.Test;
-
-// TODO find a way to make the test abort immediately if the TestAmqpPeer throws an exception
-public class ConnectionIntegrationTest extends QpidJmsTestCase
-{
-    private final IntegrationTestFixture _testFixture = new IntegrationTestFixture();
-
-    @Test
-    public void testCreateAndCloseConnection() throws Exception
-    {
-        try(TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);)
-        {
-            Connection connection = _testFixture.establishConnecton(testPeer);
-            testPeer.expectClose();
-            connection.close();
-        }
-    }
-
-    @Test
-    public void testCreateSession() throws Exception
-    {
-        try(TestAmqpPeer testPeer = new TestAmqpPeer(IntegrationTestFixture.PORT);)
-        {
-            Connection connection = _testFixture.establishConnecton(testPeer);
-            testPeer.expectBegin(true);
-            Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
-            assertNotNull("Session should not be null", session);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/qpid-jms/blob/6f106f64/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/IntegrationTestFixture.java
----------------------------------------------------------------------
diff --git a/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/IntegrationTestFixture.java b/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/IntegrationTestFixture.java
deleted file mode 100644
index 367ca1a..0000000
--- a/qpid-jms-client-tmp/src/test/java/org/apache/qpid/jms/IntegrationTestFixture.java
+++ /dev/null
@@ -1,42 +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.jms;
-
-import static org.junit.Assert.assertNull;
-
-import javax.jms.Connection;
-import javax.jms.JMSException;
-
-import org.apache.qpid.jms.impl.ConnectionImpl;
-import org.apache.qpid.jms.test.testpeer.TestAmqpPeer;
-
-public class IntegrationTestFixture
-{
-    static final int PORT = 25672;
-
-    Connection establishConnecton(TestAmqpPeer testPeer) throws JMSException
-    {
-        testPeer.expectPlainConnect("guest", "guest", true);
-
-        Connection connection =  new ConnectionImpl("clientName", "localhost", PORT, "guest", "guest");
-
-        assertNull(testPeer.getThrowable());
-        return connection;
-    }
-}


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