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 2010/05/25 16:23:52 UTC

svn commit: r948059 - /qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java

Author: robbie
Date: Tue May 25 14:23:51 2010
New Revision: 948059

URL: http://svn.apache.org/viewvc?rev=948059&view=rev
Log:
Set property for native line endings on QueuePurgeHandler

Modified:
    qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java   (contents, props changed)

Modified: qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java?rev=948059&r1=948058&r2=948059&view=diff
==============================================================================
--- qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java (original)
+++ qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java Tue May 25 14:23:51 2010
@@ -1,128 +1,128 @@
-/*
- *  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.server.handler;
-
-import org.apache.qpid.AMQException;
-import org.apache.qpid.framing.QueuePurgeBody;
-import org.apache.qpid.framing.MethodRegistry;
-import org.apache.qpid.framing.AMQMethodBody;
-import org.apache.qpid.protocol.AMQConstant;
-import org.apache.qpid.server.protocol.AMQProtocolSession;
-import org.apache.qpid.server.protocol.AMQSessionModel;
-import org.apache.qpid.server.queue.QueueRegistry;
-import org.apache.qpid.server.queue.AMQQueue;
-import org.apache.qpid.server.state.AMQStateManager;
-import org.apache.qpid.server.state.StateAwareMethodListener;
-import org.apache.qpid.server.virtualhost.VirtualHost;
-import org.apache.qpid.server.AMQChannel;
-
-public class QueuePurgeHandler implements StateAwareMethodListener<QueuePurgeBody>
-{
-    private static final QueuePurgeHandler _instance = new QueuePurgeHandler();
-
-    public static QueuePurgeHandler getInstance()
-    {
-        return _instance;
-    }
-
-    private final boolean _failIfNotFound;
-
-    public QueuePurgeHandler()
-    {
-        this(true);
-    }
-
-    public QueuePurgeHandler(boolean failIfNotFound)
-    {
-        _failIfNotFound = failIfNotFound;
-    }
-
-    public void methodReceived(AMQStateManager stateManager, QueuePurgeBody body, int channelId) throws AMQException
-    {
-        AMQProtocolSession protocolConnection = stateManager.getProtocolSession();
-        VirtualHost virtualHost = protocolConnection.getVirtualHost();
-        QueueRegistry queueRegistry = virtualHost.getQueueRegistry();
-
-        AMQChannel channel = protocolConnection.getChannel(channelId);
-
-
-        AMQQueue queue;
-        if(body.getQueue() == null)
-        {
-
-           if (channel == null)
-           {
-               throw body.getChannelNotFoundException(channelId);
-           }
-
-           //get the default queue on the channel:
-           queue = channel.getDefaultQueue();
-            
-            if(queue == null)
-            {
-                if(_failIfNotFound)
-                {
-                    throw body.getConnectionException(AMQConstant.NOT_ALLOWED,"No queue specified.");
-                }
-            }
-        }
-        else
-        {
-            queue = queueRegistry.getQueue(body.getQueue());
-        }
-
-        if(queue == null)
-        {
-            if(_failIfNotFound)
-            {
-                throw body.getChannelException(AMQConstant.NOT_FOUND, "Queue " + body.getQueue() + " does not exist.");
-            }
-        }
-        else
-        {
-                AMQSessionModel session = queue.getExclusiveOwningSession();
-
-                //Perform ACLs
-                if (!virtualHost.getAccessManager().authorisePurge(protocolConnection, queue))
-                {
-                    throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, "Permission denied");
-                }
-                else if (queue.isExclusive() && (session == null || session.getConnectionModel() != protocolConnection))
-                {
-                    throw body.getConnectionException(AMQConstant.NOT_ALLOWED,
-                                                      "Queue is exclusive, but not created on this Connection.");
-                }
-
-                long purged = queue.clearQueue();
-
-
-                if(!body.getNowait())
-                {
-
-                    MethodRegistry methodRegistry = protocolConnection.getMethodRegistry();
-                    AMQMethodBody responseBody = methodRegistry.createQueuePurgeOkBody(purged);
-                    protocolConnection.writeFrame(responseBody.generateFrame(channelId));
-
-                }
-        }
-    }
-}
+/*
+ *  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.server.handler;
+
+import org.apache.qpid.AMQException;
+import org.apache.qpid.framing.QueuePurgeBody;
+import org.apache.qpid.framing.MethodRegistry;
+import org.apache.qpid.framing.AMQMethodBody;
+import org.apache.qpid.protocol.AMQConstant;
+import org.apache.qpid.server.protocol.AMQProtocolSession;
+import org.apache.qpid.server.protocol.AMQSessionModel;
+import org.apache.qpid.server.queue.QueueRegistry;
+import org.apache.qpid.server.queue.AMQQueue;
+import org.apache.qpid.server.state.AMQStateManager;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+import org.apache.qpid.server.virtualhost.VirtualHost;
+import org.apache.qpid.server.AMQChannel;
+
+public class QueuePurgeHandler implements StateAwareMethodListener<QueuePurgeBody>
+{
+    private static final QueuePurgeHandler _instance = new QueuePurgeHandler();
+
+    public static QueuePurgeHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private final boolean _failIfNotFound;
+
+    public QueuePurgeHandler()
+    {
+        this(true);
+    }
+
+    public QueuePurgeHandler(boolean failIfNotFound)
+    {
+        _failIfNotFound = failIfNotFound;
+    }
+
+    public void methodReceived(AMQStateManager stateManager, QueuePurgeBody body, int channelId) throws AMQException
+    {
+        AMQProtocolSession protocolConnection = stateManager.getProtocolSession();
+        VirtualHost virtualHost = protocolConnection.getVirtualHost();
+        QueueRegistry queueRegistry = virtualHost.getQueueRegistry();
+
+        AMQChannel channel = protocolConnection.getChannel(channelId);
+
+
+        AMQQueue queue;
+        if(body.getQueue() == null)
+        {
+
+           if (channel == null)
+           {
+               throw body.getChannelNotFoundException(channelId);
+           }
+
+           //get the default queue on the channel:
+           queue = channel.getDefaultQueue();
+            
+            if(queue == null)
+            {
+                if(_failIfNotFound)
+                {
+                    throw body.getConnectionException(AMQConstant.NOT_ALLOWED,"No queue specified.");
+                }
+            }
+        }
+        else
+        {
+            queue = queueRegistry.getQueue(body.getQueue());
+        }
+
+        if(queue == null)
+        {
+            if(_failIfNotFound)
+            {
+                throw body.getChannelException(AMQConstant.NOT_FOUND, "Queue " + body.getQueue() + " does not exist.");
+            }
+        }
+        else
+        {
+                AMQSessionModel session = queue.getExclusiveOwningSession();
+
+                //Perform ACLs
+                if (!virtualHost.getAccessManager().authorisePurge(protocolConnection, queue))
+                {
+                    throw body.getConnectionException(AMQConstant.ACCESS_REFUSED, "Permission denied");
+                }
+                else if (queue.isExclusive() && (session == null || session.getConnectionModel() != protocolConnection))
+                {
+                    throw body.getConnectionException(AMQConstant.NOT_ALLOWED,
+                                                      "Queue is exclusive, but not created on this Connection.");
+                }
+
+                long purged = queue.clearQueue();
+
+
+                if(!body.getNowait())
+                {
+
+                    MethodRegistry methodRegistry = protocolConnection.getMethodRegistry();
+                    AMQMethodBody responseBody = methodRegistry.createQueuePurgeOkBody(purged);
+                    protocolConnection.writeFrame(responseBody.generateFrame(channelId));
+
+                }
+        }
+    }
+}

Propchange: qpid/trunk/qpid/java/broker/src/main/java/org/apache/qpid/server/handler/QueuePurgeHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native



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