You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by kp...@apache.org on 2013/10/22 00:05:07 UTC

svn commit: r1534394 [15/22] - in /qpid/branches/linearstore/qpid: ./ cpp/ cpp/bindings/qmf2/examples/python/ cpp/bindings/qmf2/python/ cpp/bindings/qpid/dotnet/ cpp/etc/ cpp/examples/ cpp/examples/messaging/ cpp/examples/qmf-agent/ cpp/include/qpid/ c...

Modified: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Demo.java
URL: http://svn.apache.org/viewvc/qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Demo.java?rev=1534394&r1=1534393&r2=1534394&view=diff
==============================================================================
--- qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Demo.java (original)
+++ qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Demo.java Mon Oct 21 22:04:51 2013
@@ -1,431 +1,430 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-package org.apache.qpid.amqp_1_0.client;
-
-import java.util.Arrays;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-import org.apache.commons.cli.HelpFormatter;
-import org.apache.commons.cli.Options;
-import org.apache.qpid.amqp_1_0.type.AmqpErrorException;
-import org.apache.qpid.amqp_1_0.type.Section;
-import org.apache.qpid.amqp_1_0.type.UnsignedInteger;
-import org.apache.qpid.amqp_1_0.type.messaging.AmqpValue;
-import org.apache.qpid.amqp_1_0.type.messaging.ApplicationProperties;
-import org.apache.qpid.amqp_1_0.type.messaging.Properties;
-
-public class Demo extends Util
-{
-    private static final String USAGE_STRING = "demo [options] <vendor> [<content> ...]\n\nOptions:";
-    private static final String OPCODE = "opcode";
-    private static final String ACTION = "action";
-    private static final String MESSAGE_ID = "message-id";
-    private static final String VENDOR = "vendor";
-    private static final String LOG = "log";
-    private static final String RECEIVED = "received";
-    private static final String TEST = "test";
-    private static final String APACHE = "apache";
-    private static final String SENT = "sent";
-    private static final String LINK_REF = "link-ref";
-    private static final String HOST = "host";
-    private static final String PORT = "port";
-    private static final String SASL_USER = "sasl-user";
-    private static final String SASL_PASSWORD = "sasl-password";
-    private static final String ROLE = "role";
-    private static final String ADDRESS = "address";
-    private static final String SENDER = "sender";
-    private static final String SEND_MESSAGE = "send-message";
-    private static final String ANNOUNCE = "announce";
-    private static final String MESSAGE_VENDOR = "message-vendor";
-    private static final String CREATE_LINK = "create-link";
-
-    public static void main(String[] args)
-    {
-        new Demo(args).run();
-    }
-
-    public Demo(String[] args)
-    {
-        super(args);
-    }
-
-    @Override
-    protected boolean hasLinkDurableOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasLinkNameOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasResponseQueueOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasSizeOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasBlockOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasStdInOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasTxnOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasModeOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasCountOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasWindowSizeOption()
-    {
-        return false;
-    }
-
-    public void run()
-    {
-
-        try
-        {
-
-            final String vendor = getArgs()[0];
-            final String queue = "control";
-
-            String message = "";
-
-            Connection conn = newConnection();
-            Session session = conn.createSession();
-
-
-            Receiver responseReceiver;
-
-            responseReceiver = session.createTemporaryQueueReceiver();
-
-
-
-
-            responseReceiver.setCredit(UnsignedInteger.valueOf(getWindowSize()), true);
-
-
-
-            Sender s = session.createSender(queue, getWindowSize(), getMode());
-
-
-            Properties properties = new Properties();
-            properties.setMessageId(java.util.UUID.randomUUID());
-            properties.setReplyTo(responseReceiver.getAddress());
-
-            HashMap appPropMap = new HashMap();
-            ApplicationProperties appProperties = new ApplicationProperties(appPropMap);
-
-            appPropMap.put(OPCODE, ANNOUNCE);
-            appPropMap.put(VENDOR, vendor);
-            appPropMap.put(ADDRESS,responseReceiver.getAddress());
-
-            AmqpValue amqpValue = new AmqpValue(message);
-            Section[] sections = { properties, appProperties, amqpValue};
-            final Message message1 = new Message(Arrays.asList(sections));
-
-            try
-            {
-                s.send(message1);
-            }
-            catch (Exception e)
-            {
-                throw new RuntimeException(e);
-            }
-
-            Map<Object, Sender> sendingLinks = new HashMap<Object, Sender>();
-            Map<Object, Receiver> receivingLinks = new HashMap<Object, Receiver>();
-
-
-            boolean done = false;
-
-            while(!done)
-            {
-                boolean wait = true;
-                Message m = responseReceiver.receive(false);
-                if(m != null)
-                {
-                    List<Section> payload = m.getPayload();
-                    wait = false;
-                    ApplicationProperties props = m.getApplicationProperties();
-                    Map map = props.getValue();
-                    String op = (String) map.get(OPCODE);
-                    if("reset".equals(op))
-                    {
-                        for(Sender sender : sendingLinks.values())
-                        {
-                            try
-                            {
-                                sender.close();
-                                Session session1 = sender.getSession();
-                                session1.close();
-                                session1.getConnection().close();
-                            }
-                            catch(Exception e)
-                            {
-                                e.printStackTrace();
-                            }
-                        }
-                        for(Receiver receiver : receivingLinks.values())
-                        {
-                            try
-                            {
-                                receiver.close();
-                                receiver.getSession().close();
-                                receiver.getSession().getConnection().close();
-                            }
-                            catch(Exception e)
-                            {
-                                e.printStackTrace();
-                            }
-                        }
-                        sendingLinks.clear();
-                        receivingLinks.clear();
-                    }
-                    else if(CREATE_LINK.equals(op))
-                    {
-                        Object linkRef = map.get(LINK_REF);
-                        String host = (String) map.get(HOST);
-                        Object o = map.get(PORT);
-                        int port = Integer.parseInt(String.valueOf(o));
-                        String user = (String) map.get(SASL_USER);
-                        String password = (String) map.get(SASL_PASSWORD);
-                        String role = (String) map.get(ROLE);
-                        String address = (String) map.get(ADDRESS);
-                        System.err.println("Host: " + host + "\tPort: " + port + "\t user: " + user +"\t password: " + password);
-                        try{
-
-
-                            Connection conn2 = new Connection(host, port, user, password, host);
-                            Session session2 = conn2.createSession();
-                            if(sendingLinks.containsKey(linkRef))
-                            {
-                                try
-                                {
-                                    sendingLinks.remove(linkRef).close();
-                                }
-                                catch (Exception e)
-                                {
-
-                                }
-                            }
-                            if(receivingLinks.containsKey(linkRef))
-                            {
-                                try
-                                {
-                                    receivingLinks.remove(linkRef).close();
-                                }
-                                catch (Exception e)
-                                {
-
-                                }
-                            }
-                            if(SENDER.equals(role))
-                            {
-
-                                System.err.println("%%% Creating sender (" + linkRef + ")");
-                                Sender sender = session2.createSender(address);
-                                sendingLinks.put(linkRef, sender);
-                            }
-                            else
-                            {
-
-                                System.err.println("%%% Creating receiver (" + linkRef + ")");
-                                Receiver receiver2 = session2.createReceiver(address);
-                                receiver2.setCredit(UnsignedInteger.valueOf(getWindowSize()), true);
-
-                                receivingLinks.put(linkRef, receiver2);
-                            }
-                        }
-                        catch(Exception e)
-                        {
-                            e.printStackTrace();
-                        }
-                    }
-                    else if(SEND_MESSAGE.equals(op))
-                    {
-                        Sender sender = sendingLinks.get(map.get(LINK_REF));
-                        Properties m2props = new Properties();
-                        Object messageId = map.get(MESSAGE_ID);
-                        m2props.setMessageId(messageId);
-                        Map m2propmap = new HashMap();
-                        m2propmap.put(OPCODE, TEST);
-                        m2propmap.put(VENDOR, vendor);
-                        ApplicationProperties m2appProps = new ApplicationProperties(m2propmap);
-                        Message m2 = new Message(Arrays.asList(m2props, m2appProps, new AmqpValue("AMQP-"+messageId)));
-                        try
-                        {
-                            sender.send(m2);
-                        }
-                        catch (Exception e)
-                        {
-                            throw new RuntimeException(e);
-                        }
-
-                        Map m3propmap = new HashMap();
-                        m3propmap.put(OPCODE, LOG);
-                        m3propmap.put(ACTION, SENT);
-                        m3propmap.put(MESSAGE_ID, messageId);
-                        m3propmap.put(VENDOR, vendor);
-                        m3propmap.put(MESSAGE_VENDOR, vendor);
-
-
-                        Message m3 = new Message(Arrays.asList(new ApplicationProperties(m3propmap),
-                                                               new AmqpValue("AMQP-"+messageId)));
-                        try
-                        {
-                            s.send(m3);
-                        }
-                        catch (Exception e)
-                        {
-                            throw new RuntimeException(e);
-                        }
-                    }
-
-                    responseReceiver.acknowledge(m);
-                }
-                else
-                {
-                    for(Map.Entry<Object, Receiver> entry : receivingLinks.entrySet())
-                    {
-                        m = entry.getValue().receive(false);
-                        if(m != null)
-                        {
-                            wait = false;
-
-                            System.err.println("%%% Received message from " + entry.getKey());
-
-                            Properties mp = m.getProperties();
-                            ApplicationProperties ap = m.getApplicationProperties();
-
-                            Map m3propmap = new HashMap();
-                            m3propmap.put(OPCODE, LOG);
-                            m3propmap.put(ACTION, RECEIVED);
-                            m3propmap.put(MESSAGE_ID, mp.getMessageId());
-                            m3propmap.put(VENDOR, vendor);
-                            m3propmap.put(MESSAGE_VENDOR, ap.getValue().get(VENDOR));
-
-                            Message m3 = new Message(Arrays.asList(new ApplicationProperties(m3propmap),
-                                                                   new AmqpValue("AMQP-"+mp.getMessageId())));
-                            try
-                            {
-                                s.send(m3);
-                            }
-                            catch (Exception e)
-                            {
-                                throw new RuntimeException(e);
-                            }
-
-                            entry.getValue().acknowledge(m);
-                        }
-
-                    }
-                }
-
-                if(wait)
-                {
-                    try
-                    {
-                        Thread.sleep(500l);
-                    }
-                    catch (InterruptedException e)
-                    {
-                        e.printStackTrace();  //TODO.
-                    }
-                }
-
-            }
-
-
-
-
-
-
-
-
-
-            s.close();
-            session.close();
-            conn.close();
-
-        }
-        catch (ConnectionException e)
-        {
-            e.printStackTrace();  //TODO.
-        }
-        catch (Sender.SenderClosingException e)
-        {
-            e.printStackTrace();  //TODO.
-        }
-        catch (Sender.SenderCreationException e)
-        {
-            e.printStackTrace();  //TODO.
-        }
-        catch (AmqpErrorException e)
-        {
-            e.printStackTrace();  //TODO.
-        }
-
-    }
-
-    protected boolean hasSingleLinkPerConnectionMode()
-    {
-        return false;
-    }
-
-    protected void printUsage(Options options)
-    {
-        HelpFormatter formatter = new HelpFormatter();
-        formatter.printHelp(USAGE_STRING, options );
-    }
-
-}
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+package org.apache.qpid.amqp_1_0.client;
+
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+import org.apache.commons.cli.HelpFormatter;
+import org.apache.commons.cli.Options;
+import org.apache.qpid.amqp_1_0.type.AmqpErrorException;
+import org.apache.qpid.amqp_1_0.type.Section;
+import org.apache.qpid.amqp_1_0.type.UnsignedInteger;
+import org.apache.qpid.amqp_1_0.type.messaging.AmqpValue;
+import org.apache.qpid.amqp_1_0.type.messaging.ApplicationProperties;
+import org.apache.qpid.amqp_1_0.type.messaging.Properties;
+
+public class Demo extends Util
+{
+    private static final String USAGE_STRING = "demo [options] <vendor> [<content> ...]\n\nOptions:";
+    private static final String OPCODE = "opcode";
+    private static final String ACTION = "action";
+    private static final String MESSAGE_ID = "message-id";
+    private static final String VENDOR = "vendor";
+    private static final String LOG = "log";
+    private static final String RECEIVED = "received";
+    private static final String TEST = "test";
+    private static final String APACHE = "apache";
+    private static final String SENT = "sent";
+    private static final String LINK_REF = "link-ref";
+    private static final String HOST = "host";
+    private static final String PORT = "port";
+    private static final String SASL_USER = "sasl-user";
+    private static final String SASL_PASSWORD = "sasl-password";
+    private static final String ROLE = "role";
+    private static final String ADDRESS = "address";
+    private static final String SENDER = "sender";
+    private static final String SEND_MESSAGE = "send-message";
+    private static final String ANNOUNCE = "announce";
+    private static final String MESSAGE_VENDOR = "message-vendor";
+    private static final String CREATE_LINK = "create-link";
+
+    public static void main(String[] args)
+    {
+        new Demo(args).run();
+    }
+
+    public Demo(String[] args)
+    {
+        super(args);
+    }
+
+    @Override
+    protected boolean hasLinkDurableOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasLinkNameOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasResponseQueueOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasSizeOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasBlockOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasStdInOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasTxnOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasModeOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasCountOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasWindowSizeOption()
+    {
+        return false;
+    }
+
+    public void run()
+    {
+
+        try
+        {
+
+            final String vendor = getArgs()[0];
+            final String queue = "control";
+
+            String message = "";
+
+            Connection conn = newConnection();
+            Session session = conn.createSession();
+
+
+            Receiver responseReceiver;
+
+            responseReceiver = session.createTemporaryQueueReceiver();
+
+
+
+
+            responseReceiver.setCredit(UnsignedInteger.valueOf(getWindowSize()), true);
+
+
+            Sender s = session.createSender(queue, getWindowSize(), getMode(), null);
+
+
+            Properties properties = new Properties();
+            properties.setMessageId(java.util.UUID.randomUUID());
+            properties.setReplyTo(responseReceiver.getAddress());
+
+            HashMap appPropMap = new HashMap();
+            ApplicationProperties appProperties = new ApplicationProperties(appPropMap);
+
+            appPropMap.put(OPCODE, ANNOUNCE);
+            appPropMap.put(VENDOR, vendor);
+            appPropMap.put(ADDRESS,responseReceiver.getAddress());
+
+            AmqpValue amqpValue = new AmqpValue(message);
+            Section[] sections = { properties, appProperties, amqpValue};
+            final Message message1 = new Message(Arrays.asList(sections));
+
+            try
+            {
+                s.send(message1);
+            }
+            catch (Exception e)
+            {
+                throw new RuntimeException(e);
+            }
+
+            Map<Object, Sender> sendingLinks = new HashMap<Object, Sender>();
+            Map<Object, Receiver> receivingLinks = new HashMap<Object, Receiver>();
+
+
+            boolean done = false;
+
+            while(!done)
+            {
+                boolean wait = true;
+                Message m = responseReceiver.receive(false);
+                if(m != null)
+                {
+                    List<Section> payload = m.getPayload();
+                    wait = false;
+                    ApplicationProperties props = m.getApplicationProperties();
+                    Map map = props.getValue();
+                    String op = (String) map.get(OPCODE);
+                    if("reset".equals(op))
+                    {
+                        for(Sender sender : sendingLinks.values())
+                        {
+                            try
+                            {
+                                sender.close();
+                                Session session1 = sender.getSession();
+                                session1.close();
+                                session1.getConnection().close();
+                            }
+                            catch(Exception e)
+                            {
+                                e.printStackTrace();
+                            }
+                        }
+                        for(Receiver receiver : receivingLinks.values())
+                        {
+                            try
+                            {
+                                receiver.close();
+                                receiver.getSession().close();
+                                receiver.getSession().getConnection().close();
+                            }
+                            catch(Exception e)
+                            {
+                                e.printStackTrace();
+                            }
+                        }
+                        sendingLinks.clear();
+                        receivingLinks.clear();
+                    }
+                    else if(CREATE_LINK.equals(op))
+                    {
+                        Object linkRef = map.get(LINK_REF);
+                        String host = (String) map.get(HOST);
+                        Object o = map.get(PORT);
+                        int port = Integer.parseInt(String.valueOf(o));
+                        String user = (String) map.get(SASL_USER);
+                        String password = (String) map.get(SASL_PASSWORD);
+                        String role = (String) map.get(ROLE);
+                        String address = (String) map.get(ADDRESS);
+                        System.err.println("Host: " + host + "\tPort: " + port + "\t user: " + user +"\t password: " + password);
+                        try{
+
+
+                            Connection conn2 = new Connection(host, port, user, password, host);
+                            Session session2 = conn2.createSession();
+                            if(sendingLinks.containsKey(linkRef))
+                            {
+                                try
+                                {
+                                    sendingLinks.remove(linkRef).close();
+                                }
+                                catch (Exception e)
+                                {
+
+                                }
+                            }
+                            if(receivingLinks.containsKey(linkRef))
+                            {
+                                try
+                                {
+                                    receivingLinks.remove(linkRef).close();
+                                }
+                                catch (Exception e)
+                                {
+
+                                }
+                            }
+                            if(SENDER.equals(role))
+                            {
+
+                                System.err.println("%%% Creating sender (" + linkRef + ")");
+                                Sender sender = session2.createSender(address);
+                                sendingLinks.put(linkRef, sender);
+                            }
+                            else
+                            {
+
+                                System.err.println("%%% Creating receiver (" + linkRef + ")");
+                                Receiver receiver2 = session2.createReceiver(address);
+                                receiver2.setCredit(UnsignedInteger.valueOf(getWindowSize()), true);
+
+                                receivingLinks.put(linkRef, receiver2);
+                            }
+                        }
+                        catch(Exception e)
+                        {
+                            e.printStackTrace();
+                        }
+                    }
+                    else if(SEND_MESSAGE.equals(op))
+                    {
+                        Sender sender = sendingLinks.get(map.get(LINK_REF));
+                        Properties m2props = new Properties();
+                        Object messageId = map.get(MESSAGE_ID);
+                        m2props.setMessageId(messageId);
+                        Map m2propmap = new HashMap();
+                        m2propmap.put(OPCODE, TEST);
+                        m2propmap.put(VENDOR, vendor);
+                        ApplicationProperties m2appProps = new ApplicationProperties(m2propmap);
+                        Message m2 = new Message(Arrays.asList(m2props, m2appProps, new AmqpValue("AMQP-"+messageId)));
+                        try
+                        {
+                            sender.send(m2);
+                        }
+                        catch (Exception e)
+                        {
+                            throw new RuntimeException(e);
+                        }
+
+                        Map m3propmap = new HashMap();
+                        m3propmap.put(OPCODE, LOG);
+                        m3propmap.put(ACTION, SENT);
+                        m3propmap.put(MESSAGE_ID, messageId);
+                        m3propmap.put(VENDOR, vendor);
+                        m3propmap.put(MESSAGE_VENDOR, vendor);
+
+
+                        Message m3 = new Message(Arrays.asList(new ApplicationProperties(m3propmap),
+                                                               new AmqpValue("AMQP-"+messageId)));
+                        try
+                        {
+                            s.send(m3);
+                        }
+                        catch (Exception e)
+                        {
+                            throw new RuntimeException(e);
+                        }
+                    }
+
+                    responseReceiver.acknowledge(m);
+                }
+                else
+                {
+                    for(Map.Entry<Object, Receiver> entry : receivingLinks.entrySet())
+                    {
+                        m = entry.getValue().receive(false);
+                        if(m != null)
+                        {
+                            wait = false;
+
+                            System.err.println("%%% Received message from " + entry.getKey());
+
+                            Properties mp = m.getProperties();
+                            ApplicationProperties ap = m.getApplicationProperties();
+
+                            Map m3propmap = new HashMap();
+                            m3propmap.put(OPCODE, LOG);
+                            m3propmap.put(ACTION, RECEIVED);
+                            m3propmap.put(MESSAGE_ID, mp.getMessageId());
+                            m3propmap.put(VENDOR, vendor);
+                            m3propmap.put(MESSAGE_VENDOR, ap.getValue().get(VENDOR));
+
+                            Message m3 = new Message(Arrays.asList(new ApplicationProperties(m3propmap),
+                                                                   new AmqpValue("AMQP-"+mp.getMessageId())));
+                            try
+                            {
+                                s.send(m3);
+                            }
+                            catch (Exception e)
+                            {
+                                throw new RuntimeException(e);
+                            }
+
+                            entry.getValue().acknowledge(m);
+                        }
+
+                    }
+                }
+
+                if(wait)
+                {
+                    try
+                    {
+                        Thread.sleep(500l);
+                    }
+                    catch (InterruptedException e)
+                    {
+                        e.printStackTrace();  //TODO.
+                    }
+                }
+
+            }
+
+
+
+
+
+
+
+
+
+            s.close();
+            session.close();
+            conn.close();
+
+        }
+        catch (ConnectionException e)
+        {
+            e.printStackTrace();  //TODO.
+        }
+        catch (Sender.SenderClosingException e)
+        {
+            e.printStackTrace();  //TODO.
+        }
+        catch (Sender.SenderCreationException e)
+        {
+            e.printStackTrace();  //TODO.
+        }
+        catch (AmqpErrorException e)
+        {
+            e.printStackTrace();  //TODO.
+        }
+
+    }
+
+    protected boolean hasSingleLinkPerConnectionMode()
+    {
+        return false;
+    }
+
+    protected void printUsage(Options options)
+    {
+        HelpFormatter formatter = new HelpFormatter();
+        formatter.printHelp(USAGE_STRING, options );
+    }
+
+}

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Demo.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Dump.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Filereceiver.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Filesender.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Receive.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Request.java
URL: http://svn.apache.org/viewvc/qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Request.java?rev=1534394&r1=1534393&r2=1534394&view=diff
==============================================================================
--- qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Request.java (original)
+++ qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Request.java Mon Oct 21 22:04:51 2013
@@ -1,236 +1,234 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-package org.apache.qpid.amqp_1_0.client;
-
-import org.apache.qpid.amqp_1_0.type.AmqpErrorException;
-import org.apache.qpid.amqp_1_0.type.Section;
-import org.apache.qpid.amqp_1_0.type.UnsignedInteger;
-import org.apache.qpid.amqp_1_0.type.UnsignedLong;
-import org.apache.qpid.amqp_1_0.type.messaging.AmqpValue;
-import org.apache.qpid.amqp_1_0.type.messaging.Header;
-import org.apache.qpid.amqp_1_0.type.messaging.Properties;
-import org.apache.commons.cli.*;
-
-import java.util.Arrays;
-
-public class Request extends Util
-{
-    private static final String USAGE_STRING = "request [options] <address> [<content> ...]\n\nOptions:";
-
-    public static void main(String[] args)
-    {
-        new Request(args).run();
-    }
-
-    public Request(String[] args)
-    {
-        super(args);
-    }
-
-    @Override
-    protected boolean hasLinkDurableOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasLinkNameOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasResponseQueueOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasSizeOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasBlockOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasStdInOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasTxnOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasModeOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasCountOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasWindowSizeOption()
-    {
-        return true;
-    }
-
-    public void run()
-    {
-
-        try
-        {
-
-
-            final String queue = getArgs()[0];
-
-            String message = "";
-
-            Connection conn = newConnection();
-            Session session = conn.createSession();
-
-            Connection conn2;
-            Session session2;
-            Receiver responseReceiver;
-
-            if(isUseMultipleConnections())
-            {
-                conn2 = newConnection();
-                session2 = conn2.createSession();
-                responseReceiver = session2.createTemporaryQueueReceiver();
-            }
-            else
-            {
-                conn2 = null;
-                session2 = null;
-                responseReceiver = session.createTemporaryQueueReceiver();
-            }
-
-
-
-
-            responseReceiver.setCredit(UnsignedInteger.valueOf(getWindowSize()), true);
-
-
-
-            Sender s = session.createSender(queue, getWindowSize(), getMode());
-
-            Transaction txn = null;
-
-            if(useTran())
-            {
-                txn = session.createSessionLocalTransaction();
-            }
-
-            int received = 0;
-
-            if(getArgs().length >= 2)
-            {
-                message = getArgs()[1];
-                if(message.length() < getMessageSize())
-                {
-                    StringBuilder builder = new StringBuilder(getMessageSize());
-                    builder.append(message);
-                    for(int x = message.length(); x < getMessageSize(); x++)
-                    {
-                        builder.append('.');
-                    }
-                    message = builder.toString();
-                }
-
-                for(int i = 0; i < getCount(); i++)
-                {
-                    Properties properties = new Properties();
-                    properties.setMessageId(UnsignedLong.valueOf(i));
-                    properties.setReplyTo(responseReceiver.getAddress());
-
-                    AmqpValue amqpValue = new AmqpValue(message);
-                    Section[] sections = { new Header() , properties, amqpValue};
-                    final Message message1 = new Message(Arrays.asList(sections));
-
-                    s.send(message1, txn);
-
-                    Message responseMessage = responseReceiver.receive(false);
-                    if(responseMessage != null)
-                    {
-                        responseReceiver.acknowledge(responseMessage.getDeliveryTag(),txn);
-                        received++;
-                    }
-                }
-            }
-
-            if(txn != null)
-            {
-                txn.commit();
-            }
-
-
-            while(received < getCount())
-            {
-                Message responseMessage = responseReceiver.receive();
-                responseReceiver.acknowledge(responseMessage.getDeliveryTag());
-                received++;
-            }
-
-
-
-
-            s.close();
-            session.close();
-            conn.close();
-
-            if(session2 != null)
-            {
-                session2.close();
-                conn2.close();
-            }
-        }
-        catch (Exception e)
-        {
-            e.printStackTrace();  //TODO.
-        }
-    }
-
-    protected boolean hasSingleLinkPerConnectionMode()
-    {
-        return true;
-    }
-
-    protected void printUsage(Options options)
-    {
-        HelpFormatter formatter = new HelpFormatter();
-        formatter.printHelp(USAGE_STRING, options );
-    }
-
-}
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+package org.apache.qpid.amqp_1_0.client;
+
+import org.apache.qpid.amqp_1_0.type.Section;
+import org.apache.qpid.amqp_1_0.type.UnsignedInteger;
+import org.apache.qpid.amqp_1_0.type.UnsignedLong;
+import org.apache.qpid.amqp_1_0.type.messaging.AmqpValue;
+import org.apache.qpid.amqp_1_0.type.messaging.Header;
+import org.apache.qpid.amqp_1_0.type.messaging.Properties;
+import org.apache.commons.cli.*;
+
+import java.util.Arrays;
+
+public class Request extends Util
+{
+    private static final String USAGE_STRING = "request [options] <address> [<content> ...]\n\nOptions:";
+
+    public static void main(String[] args)
+    {
+        new Request(args).run();
+    }
+
+    public Request(String[] args)
+    {
+        super(args);
+    }
+
+    @Override
+    protected boolean hasLinkDurableOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasLinkNameOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasResponseQueueOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasSizeOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasBlockOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasStdInOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasTxnOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasModeOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasCountOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasWindowSizeOption()
+    {
+        return true;
+    }
+
+    public void run()
+    {
+
+        try
+        {
+
+
+            final String queue = getArgs()[0];
+
+            String message = "";
+
+            Connection conn = newConnection();
+            Session session = conn.createSession();
+
+            Connection conn2;
+            Session session2;
+            Receiver responseReceiver;
+
+            if(isUseMultipleConnections())
+            {
+                conn2 = newConnection();
+                session2 = conn2.createSession();
+                responseReceiver = session2.createTemporaryQueueReceiver();
+            }
+            else
+            {
+                conn2 = null;
+                session2 = null;
+                responseReceiver = session.createTemporaryQueueReceiver();
+            }
+
+
+
+
+            responseReceiver.setCredit(UnsignedInteger.valueOf(getWindowSize()), true);
+
+
+            Sender s = session.createSender(queue, getWindowSize(), getMode(), null);
+
+            Transaction txn = null;
+
+            if(useTran())
+            {
+                txn = session.createSessionLocalTransaction();
+            }
+
+            int received = 0;
+
+            if(getArgs().length >= 2)
+            {
+                message = getArgs()[1];
+                if(message.length() < getMessageSize())
+                {
+                    StringBuilder builder = new StringBuilder(getMessageSize());
+                    builder.append(message);
+                    for(int x = message.length(); x < getMessageSize(); x++)
+                    {
+                        builder.append('.');
+                    }
+                    message = builder.toString();
+                }
+
+                for(int i = 0; i < getCount(); i++)
+                {
+                    Properties properties = new Properties();
+                    properties.setMessageId(UnsignedLong.valueOf(i));
+                    properties.setReplyTo(responseReceiver.getAddress());
+
+                    AmqpValue amqpValue = new AmqpValue(message);
+                    Section[] sections = { new Header() , properties, amqpValue};
+                    final Message message1 = new Message(Arrays.asList(sections));
+
+                    s.send(message1, txn);
+
+                    Message responseMessage = responseReceiver.receive(false);
+                    if(responseMessage != null)
+                    {
+                        responseReceiver.acknowledge(responseMessage.getDeliveryTag(),txn);
+                        received++;
+                    }
+                }
+            }
+
+            if(txn != null)
+            {
+                txn.commit();
+            }
+
+
+            while(received < getCount())
+            {
+                Message responseMessage = responseReceiver.receive();
+                responseReceiver.acknowledge(responseMessage.getDeliveryTag());
+                received++;
+            }
+
+
+
+
+            s.close();
+            session.close();
+            conn.close();
+
+            if(session2 != null)
+            {
+                session2.close();
+                conn2.close();
+            }
+        }
+        catch (Exception e)
+        {
+            e.printStackTrace();  //TODO.
+        }
+    }
+
+    protected boolean hasSingleLinkPerConnectionMode()
+    {
+        return true;
+    }
+
+    protected void printUsage(Options options)
+    {
+        HelpFormatter formatter = new HelpFormatter();
+        formatter.printHelp(USAGE_STRING, options );
+    }
+
+}

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Request.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Respond.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Send.java
URL: http://svn.apache.org/viewvc/qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Send.java?rev=1534394&r1=1534393&r2=1534394&view=diff
==============================================================================
--- qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Send.java (original)
+++ qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Send.java Mon Oct 21 22:04:51 2013
@@ -1,235 +1,235 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- *
- */
-
-package org.apache.qpid.amqp_1_0.client;
-
-import java.io.IOException;
-import java.io.InputStreamReader;
-import java.io.LineNumberReader;
-import java.util.Arrays;
-
-import org.apache.qpid.amqp_1_0.type.Binary;
-import org.apache.qpid.amqp_1_0.type.Section;
-import org.apache.qpid.amqp_1_0.type.UnsignedLong;
-import org.apache.qpid.amqp_1_0.type.messaging.AmqpValue;
-import org.apache.qpid.amqp_1_0.type.messaging.Data;
-import org.apache.qpid.amqp_1_0.type.messaging.Properties;
-import org.apache.commons.cli.*;
-
-public class Send extends Util
-{
-    private static final String USAGE_STRING = "send [options] <address> [<content> ...]\n\nOptions:";
-    private static final char[] HEX =  {'0','1','2','3','4','5','6','7','8','9','A','B','C','D','E','F'};
-
-
-    public static void main(String[] args) throws Sender.SenderCreationException, Sender.SenderClosingException, ConnectionException
-    {
-        new Send(args).run();
-    }
-
-
-    public Send(final String[] args)
-    {
-        super(args);
-    }
-
-    @Override
-    protected boolean hasLinkDurableOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasLinkNameOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasResponseQueueOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasSizeOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasBlockOption()
-    {
-        return false;
-    }
-
-    @Override
-    protected boolean hasStdInOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasTxnOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasModeOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasCountOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasWindowSizeOption()
-    {
-        return true;
-    }
-
-    @Override
-    protected boolean hasSubjectOption()
-    {
-        return true;
-    }
-
-    public void run()
-    {
-
-        final String queue = getArgs()[0];
-
-        String message = "";
-
-        try
-        {
-            Connection conn = newConnection();
-
-            Session session = conn.createSession();
-
-
-            Sender s = session.createSender(queue, getWindowSize(), getMode(), getLinkName());
-
-            Transaction txn = null;
-
-            if(useTran())
-            {
-                txn = session.createSessionLocalTransaction();
-            }
-
-            if(!useStdIn())
-            {
-                if(getArgs().length <= 2)
-                {
-                    if(getArgs().length == 2)
-                    {
-                        message = getArgs()[1];
-                    }
-                    for(int i = 0; i < getCount(); i++)
-                    {
-
-                        Properties properties = new Properties();
-                        properties.setMessageId(UnsignedLong.valueOf(i));
-                        if(getSubject() != null)
-                        {
-                            properties.setSubject(getSubject());
-                        }
-                        Section bodySection;
-                        byte[] bytes = (message + "  " + i).getBytes();
-                        if(bytes.length < getMessageSize())
-                        {
-                            byte[] origBytes = bytes;
-                            bytes = new byte[getMessageSize()];
-                            System.arraycopy(origBytes,0,bytes,0,origBytes.length);
-                            for(int x = origBytes.length; x < bytes.length; x++)
-                            {
-                                bytes[x] = (byte) '.';
-                            }
-                            bodySection = new Data(new Binary(bytes));
-                        }
-                        else
-                        {
-                            bodySection = new AmqpValue(message + " " + i);
-                        }
-
-                        Section[] sections = {properties, bodySection};
-                        final Message message1 = new Message(Arrays.asList(sections));
-
-                        s.send(message1, txn);
-                    }
-                }
-                else
-                {
-                    for(int i = 1; i < getArgs().length; i++)
-                    {
-                        s.send(new Message(getArgs()[i]), txn);
-                    }
-
-                }
-            }
-            else
-            {
-                LineNumberReader buf = new LineNumberReader(new InputStreamReader(System.in));
-
-
-                try
-                {
-                    while((message = buf.readLine()) != null)
-                    {
-                        s.send(new Message(message), txn);
-                    }
-                }
-                catch (IOException e)
-                {
-    // TODO
-                    e.printStackTrace();
-                }
-            }
-
-            if(txn != null)
-            {
-                txn.commit();
-            }
-
-            s.close();
-
-            session.close();
-            conn.close();
-        }
-        catch (Exception e)
-        {
-            e.printStackTrace();  //TODO.
-        }
-
-    }
-
-    protected void printUsage(Options options)
-    {
-        HelpFormatter formatter = new HelpFormatter();
-        formatter.printHelp(USAGE_STRING, options );
-    }
-
-}
+/*
+ *
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+package org.apache.qpid.amqp_1_0.client;
+
+import java.io.IOException;
+import java.io.InputStreamReader;
+import java.io.LineNumberReader;
+import java.util.Arrays;
+
+import org.apache.qpid.amqp_1_0.type.Binary;
+import org.apache.qpid.amqp_1_0.type.Section;
+import org.apache.qpid.amqp_1_0.type.UnsignedLong;
+import org.apache.qpid.amqp_1_0.type.messaging.AmqpValue;
+import org.apache.qpid.amqp_1_0.type.messaging.Data;
+import org.apache.qpid.amqp_1_0.type.messaging.Properties;
+import org.apache.commons.cli.*;
+
+public class Send extends Util
+{
+    private static final String USAGE_STRING = "send [options] <address> [<content> ...]\n\nOptions:";
+    private static final char[] HEX =  {'0','1','2','3','4','5','6','7','8','9','A','B','C','D','E','F'};
+
+
+    public static void main(String[] args) throws Sender.SenderCreationException, Sender.SenderClosingException, ConnectionException
+    {
+        new Send(args).run();
+    }
+
+
+    public Send(final String[] args)
+    {
+        super(args);
+    }
+
+    @Override
+    protected boolean hasLinkDurableOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasLinkNameOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasResponseQueueOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasSizeOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasBlockOption()
+    {
+        return false;
+    }
+
+    @Override
+    protected boolean hasStdInOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasTxnOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasModeOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasCountOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasWindowSizeOption()
+    {
+        return true;
+    }
+
+    @Override
+    protected boolean hasSubjectOption()
+    {
+        return true;
+    }
+
+    public void run()
+    {
+
+        final String queue = getArgs()[0];
+
+        String message = "";
+
+        try
+        {
+            Connection conn = newConnection();
+
+            Session session = conn.createSession();
+
+
+            Sender s = session.createSender(queue, getWindowSize(), getMode(), getLinkName());
+
+            Transaction txn = null;
+
+            if(useTran())
+            {
+                txn = session.createSessionLocalTransaction();
+            }
+
+            if(!useStdIn())
+            {
+                if(getArgs().length <= 2)
+                {
+                    if(getArgs().length == 2)
+                    {
+                        message = getArgs()[1];
+                    }
+                    for(int i = 0; i < getCount(); i++)
+                    {
+
+                        Properties properties = new Properties();
+                        properties.setMessageId(UnsignedLong.valueOf(i));
+                        if(getSubject() != null)
+                        {
+                            properties.setSubject(getSubject());
+                        }
+                        Section bodySection;
+                        byte[] bytes = (message + "  " + i).getBytes();
+                        if(bytes.length < getMessageSize())
+                        {
+                            byte[] origBytes = bytes;
+                            bytes = new byte[getMessageSize()];
+                            System.arraycopy(origBytes,0,bytes,0,origBytes.length);
+                            for(int x = origBytes.length; x < bytes.length; x++)
+                            {
+                                bytes[x] = (byte) '.';
+                            }
+                            bodySection = new Data(new Binary(bytes));
+                        }
+                        else
+                        {
+                            bodySection = new AmqpValue(message + " " + i);
+                        }
+
+                        Section[] sections = {properties, bodySection};
+                        final Message message1 = new Message(Arrays.asList(sections));
+
+                        s.send(message1, txn);
+                    }
+                }
+                else
+                {
+                    for(int i = 1; i < getArgs().length; i++)
+                    {
+                        s.send(new Message(getArgs()[i]), txn);
+                    }
+
+                }
+            }
+            else
+            {
+                LineNumberReader buf = new LineNumberReader(new InputStreamReader(System.in));
+
+
+                try
+                {
+                    while((message = buf.readLine()) != null)
+                    {
+                        s.send(new Message(message), txn);
+                    }
+                }
+                catch (IOException e)
+                {
+    // TODO
+                    e.printStackTrace();
+                }
+            }
+
+            if(txn != null)
+            {
+                txn.commit();
+            }
+
+            s.close();
+
+            session.close();
+            conn.close();
+        }
+        catch (Exception e)
+        {
+            e.printStackTrace();  //TODO.
+        }
+
+    }
+
+    protected void printUsage(Options options)
+    {
+        HelpFormatter formatter = new HelpFormatter();
+        formatter.printHelp(USAGE_STRING, options );
+    }
+
+}

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Send.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Util.java
URL: http://svn.apache.org/viewvc/qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Util.java?rev=1534394&r1=1534393&r2=1534394&view=diff
==============================================================================
--- qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Util.java (original)
+++ qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Util.java Mon Oct 21 22:04:51 2013
@@ -502,9 +502,11 @@ public abstract class Util
     {
         Container container = getContainerName() == null ? new Container() : new Container(getContainerName());
         return getUsername() == null ? new Connection(getHost(), getPort(), null, null, _frameSize, container,
-                                                      _remoteHost == null ? getHost() : _remoteHost, _useSSL)
+                                                      _remoteHost == null ? getHost() : _remoteHost, _useSSL,
+                                                      0)
                                      : new Connection(getHost(), getPort(), getUsername(), getPassword(), _frameSize,
-                                                      container, _remoteHost == null ? getHost() : _remoteHost, _useSSL);
+                                                      container, _remoteHost == null ? getHost() : _remoteHost, _useSSL,
+                                                      0);
     }
 
     public String getContainerName()

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/example/src/main/java/org/apache/qpid/amqp_1_0/client/Util.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: qpid/branches/linearstore/qpid/java/amqp-1-0-client/src/main/java/org/apache/qpid/amqp_1_0/client/AcknowledgeMode.java
------------------------------------------------------------------------------
    svn:eol-style = native



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