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 2007/01/09 20:47:03 UTC

svn commit: r494541 - in /incubator/qpid/branches/qpid.0-9/java: broker/src/main/java/org/apache/qpid/server/handler/ broker/src/main/java/org/apache/qpid/server/protocol/ broker/src/main/java/org/apache/qpid/server/state/ common/ common/src/main/java/...

Author: kpvdr
Date: Tue Jan  9 11:47:02 2007
New Revision: 494541

URL: http://svn.apache.org/viewvc?view=rev&rev=494541
Log:
New broker Messafe class handelrs added, removed old Basic* handlers; New framing Request and Response classes added

Added:
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageAppendHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCancelHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCheckpointHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCloseHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageConsumeHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageEmptyHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageGetHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOffsetHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOkHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOpenHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageQosHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRecoverHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRejectHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageResumeHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageTransferHandler.java
    incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequestBody.java
      - copied, changed from r494058, incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequest.java
    incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponseBody.java
      - copied, changed from r494058, incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponse.java
Removed:
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/BasicAckMethodHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/BasicCancelMethodHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/BasicConsumeMethodHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/BasicPublishMethodHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/BasicQosHandler.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/BasicRecoverMethodHandler.java
    incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequest.java
    incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponse.java
Modified:
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQMinaProtocolSession.java
    incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/state/AMQStateManager.java
    incubator/qpid/branches/qpid.0-9/java/common/protocol-version.xml

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageAppendHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageAppendHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageAppendHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageAppendHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageAppendBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageAppendHandler implements StateAwareMethodListener<MessageAppendBody>
+{
+    private static MessageAppendHandler _instance = new MessageAppendHandler();
+
+    public static MessageAppendHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageAppendHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageAppendBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCancelHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCancelHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCancelHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCancelHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageCancelBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageCancelHandler implements StateAwareMethodListener<MessageCancelBody>
+{
+    private static MessageCancelHandler _instance = new MessageCancelHandler();
+
+    public static MessageCancelHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageCancelHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageCancelBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCheckpointHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCheckpointHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCheckpointHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCheckpointHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageCheckpointBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageCheckpointHandler implements StateAwareMethodListener<MessageCheckpointBody>
+{
+    private static MessageCheckpointHandler _instance = new MessageCheckpointHandler();
+
+    public static MessageCheckpointHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageCheckpointHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageCheckpointBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCloseHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCloseHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCloseHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageCloseHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageCloseBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageCloseHandler implements StateAwareMethodListener<MessageCloseBody>
+{
+    private static MessageCloseHandler _instance = new MessageCloseHandler();
+
+    public static MessageCloseHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageCloseHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageCloseBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageConsumeHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageConsumeHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageConsumeHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageConsumeHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageConsumeBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageConsumeHandler implements StateAwareMethodListener<MessageConsumeBody>
+{
+    private static MessageConsumeHandler _instance = new MessageConsumeHandler();
+
+    public static MessageConsumeHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageConsumeHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageConsumeBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageEmptyHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageEmptyHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageEmptyHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageEmptyHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageEmptyBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageEmptyHandler implements StateAwareMethodListener<MessageEmptyBody>
+{
+    private static MessageEmptyHandler _instance = new MessageEmptyHandler();
+
+    public static MessageEmptyHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageEmptyHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageEmptyBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageGetHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageGetHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageGetHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageGetHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,47 @@
+/*
+ *
+ * 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.framing.MessageGetBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageGetHandler implements StateAwareMethodListener<MessageGetBody>
+{
+    private static MessageGetHandler _instance = new MessageGetHandler();
+
+    public static MessageGetHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageGetHandler() {}
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageGetBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOffsetHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOffsetHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOffsetHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOffsetHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageOffsetBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageOffsetHandler implements StateAwareMethodListener<MessageOffsetBody>
+{
+    private static MessageOffsetHandler _instance = new MessageOffsetHandler();
+
+    public static MessageOffsetHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageOffsetHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageOffsetBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOkHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOkHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOkHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOkHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageOkBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageOkHandler implements StateAwareMethodListener<MessageOkBody>
+{
+    private static MessageOkHandler _instance = new MessageOkHandler();
+
+    public static MessageOkHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageOkHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageOkBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOpenHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOpenHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOpenHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageOpenHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageOpenBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageOpenHandler implements StateAwareMethodListener<MessageOpenBody>
+{
+    private static MessageOpenHandler _instance = new MessageOpenHandler();
+
+    public static MessageOpenHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageOpenHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageOpenBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageQosHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageQosHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageQosHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageQosHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageQosBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageQosHandler implements StateAwareMethodListener<MessageQosBody>
+{
+    private static MessageQosHandler _instance = new MessageQosHandler();
+
+    public static MessageQosHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageQosHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageQosBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRecoverHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRecoverHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRecoverHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRecoverHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageRecoverBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageRecoverHandler implements StateAwareMethodListener<MessageRecoverBody>
+{
+    private static MessageRecoverHandler _instance = new MessageRecoverHandler();
+
+    public static MessageRecoverHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageRecoverHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageRecoverBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRejectHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRejectHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRejectHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageRejectHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageRejectBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageRejectHandler implements StateAwareMethodListener<MessageRejectBody>
+{
+    private static MessageRejectHandler _instance = new MessageRejectHandler();
+
+    public static MessageRejectHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageRejectHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageRejectBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageResumeHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageResumeHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageResumeHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageResumeHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageResumeBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageResumeHandler implements StateAwareMethodListener<MessageResumeBody>
+{
+    private static MessageResumeHandler _instance = new MessageResumeHandler();
+
+    public static MessageResumeHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageResumeHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageResumeBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Added: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageTransferHandler.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageTransferHandler.java?view=auto&rev=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageTransferHandler.java (added)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/handler/MessageTransferHandler.java Tue Jan  9 11:47:02 2007
@@ -0,0 +1,48 @@
+/*
+ *
+ * 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.framing.MessageTransferBody;
+import org.apache.qpid.server.state.StateAwareMethodListener;
+
+public class MessageTransferHandler implements StateAwareMethodListener<MessageTransferBody>
+{
+    private static MessageTransferHandler _instance = new MessageTransferHandler();
+
+    public static MessageTransferHandler getInstance()
+    {
+        return _instance;
+    }
+
+    private MessageTransferHandler() {}
+    
+    
+    public void methodReceived (AMQStateManager stateManager,
+    							QueueRegistry queueRegistry,
+                              	ExchangeRegistry exchangeRegistry,
+                                AMQProtocolSession protocolSession,
+                               	AMQMethodEvent<MessageTransferBody> evt)
+                                throws AMQException
+    {
+		// TODO
+    }
+}
+

Modified: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQMinaProtocolSession.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQMinaProtocolSession.java?view=diff&rev=494541&r1=494540&r2=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQMinaProtocolSession.java (original)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/protocol/AMQMinaProtocolSession.java Tue Jan  9 11:47:02 2007
@@ -195,7 +195,15 @@
         {
             AMQFrame frame = (AMQFrame) message;
 
-            if (frame.bodyFrame instanceof AMQMethodBody)
+            if (frame.bodyFrame instanceof AMQRequest)
+            {
+            	requestFrameReceived(frame);
+            }
+            else if (frame.bodyFrame instanceof AMQResponse)
+            {
+            	responseFrameReceived(frame);
+            }
+            else if (frame.bodyFrame instanceof AMQMethodBody)
             {
                 methodFrameReceived(frame);
             }
@@ -213,6 +221,22 @@
                     writeFrame(e.getReturnMessage(frame.channel));
                 }
             }
+        }
+    }
+    
+    private void requestFrameReceived(AMQFrame frame)
+    {
+        if (_logger.isDebugEnabled())
+        {
+            _logger.debug("Request frame received: " + frame);
+        }
+    }
+    
+    private void responseFrameReceived(AMQFrame frame)
+    {
+        if (_logger.isDebugEnabled())
+        {
+            _logger.debug("Response frame received: " + frame);
         }
     }
 

Modified: incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/state/AMQStateManager.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/state/AMQStateManager.java?view=diff&rev=494541&r1=494540&r2=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/state/AMQStateManager.java (original)
+++ incubator/qpid/branches/qpid.0-9/java/broker/src/main/java/org/apache/qpid/server/state/AMQStateManager.java Tue Jan  9 11:47:02 2007
@@ -110,12 +110,21 @@
         frame2handlerMap.put(ExchangeDeclareBody.class, ExchangeDeclareHandler.getInstance());
         frame2handlerMap.put(ExchangeDeleteBody.class, ExchangeDeleteHandler.getInstance());
         frame2handlerMap.put(ExchangeBoundBody.class, ExchangeBoundHandler.getInstance());
-        frame2handlerMap.put(BasicAckBody.class, BasicAckMethodHandler.getInstance());
-        frame2handlerMap.put(BasicRecoverBody.class, BasicRecoverMethodHandler.getInstance());
-        frame2handlerMap.put(BasicConsumeBody.class, BasicConsumeMethodHandler.getInstance());
-        frame2handlerMap.put(BasicCancelBody.class, BasicCancelMethodHandler.getInstance());
-        frame2handlerMap.put(BasicPublishBody.class, BasicPublishMethodHandler.getInstance());
-        frame2handlerMap.put(BasicQosBody.class, BasicQosHandler.getInstance());
+        frame2handlerMap.put(MessageAppendBody.class, MessageAppendHandler.getInstance());
+        frame2handlerMap.put(MessageCancelBody.class, MessageCancelHandler.getInstance());
+        frame2handlerMap.put(MessageCheckpointBody.class, MessageCheckpointHandler.getInstance());
+        frame2handlerMap.put(MessageCloseBody.class, MessageCloseHandler.getInstance());
+        frame2handlerMap.put(MessageConsumeBody.class, MessageConsumeHandler.getInstance());
+        frame2handlerMap.put(MessageEmptyBody.class, MessageEmptyHandler.getInstance());
+        frame2handlerMap.put(MessageGetBody.class, MessageGetHandler.getInstance());
+        frame2handlerMap.put(MessageOffsetBody.class, MessageOffsetHandler.getInstance());
+        frame2handlerMap.put(MessageOkBody.class, MessageOkHandler.getInstance());
+        frame2handlerMap.put(MessageOpenBody.class, MessageOpenHandler.getInstance());
+        frame2handlerMap.put(MessageQosBody.class, MessageQosHandler.getInstance());
+        frame2handlerMap.put(MessageRecoverBody.class, MessageRecoverHandler.getInstance());
+        frame2handlerMap.put(MessageRejectBody.class, MessageRejectHandler.getInstance());
+        frame2handlerMap.put(MessageResumeBody.class, MessageResumeHandler.getInstance());
+        frame2handlerMap.put(MessageTransferBody.class, MessageTransferHandler.getInstance());
         frame2handlerMap.put(QueueBindBody.class, QueueBindHandler.getInstance());
         frame2handlerMap.put(QueueDeclareBody.class, QueueDeclareHandler.getInstance());
         frame2handlerMap.put(QueueDeleteBody.class, QueueDeleteHandler.getInstance());

Modified: incubator/qpid/branches/qpid.0-9/java/common/protocol-version.xml
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/common/protocol-version.xml?view=diff&rev=494541&r1=494540&r2=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/common/protocol-version.xml (original)
+++ incubator/qpid/branches/qpid.0-9/java/common/protocol-version.xml Tue Jan  9 11:47:02 2007
@@ -27,8 +27,8 @@
   <property name="generated.dir" location="${generated.path}/${generated.package}" />
   <property name="generated.timestamp" location="${generated.dir}/timestamp" />
   <property name="xml.spec.dir" location="${topDirectoryLocation}/../specs" />
-  <property name="xml.spec.deps" value="amqp.0-9.xml cluster.0-9.xml amqp-nogen.0-9.xml" />
-  <property name="xml.spec.list" value="${xml.spec.dir}/amqp.0-9.xml ${xml.spec.dir}/cluster.0-9.xml ${xml.spec.dir}/amqp-nogen.0-9.xml" />
+  <property name="xml.spec.deps" value="amqp.0-9.xml cluster.0-9.xml exchange-bound.0-9.xml amqp-nogen.0-9.xml" />
+  <property name="xml.spec.list" value="${xml.spec.dir}/amqp.0-9.xml ${xml.spec.dir}/cluster.0-9.xml ${xml.spec.dir}/exchange-bound.0-9.xml ${xml.spec.dir}/amqp-nogen.0-9.xml" />
   	
   <target name="generate" depends="compile_generator,check_generate_deps" unless="generation.notRequired">
     <mkdir dir="${generated.dir}"/>

Copied: incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequestBody.java (from r494058, incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequest.java)
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequestBody.java?view=diff&rev=494541&p1=incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequest.java&r1=494058&p2=incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequestBody.java&r2=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequest.java (original)
+++ incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQRequestBody.java Tue Jan  9 11:47:02 2007
@@ -22,7 +22,7 @@
 
 import org.apache.mina.common.ByteBuffer;
 
-public class AMQRequest extends AMQBody
+public class AMQRequestBody extends AMQBody
 {
     public static final byte TYPE = (byte)AmqpConstants.frameRequestAsInt();
        
@@ -33,7 +33,7 @@
 
 
     // Constructor
-    public AMQRequest() {}
+    public AMQRequestBody() {}
 
     // Field methods
     
@@ -72,7 +72,7 @@
     public static AMQFrame createAMQFrame(int channelId, long requestId,
             long responseMark, AMQMethodBody methodPayload)
     {
-        AMQResponse responseFrame = new AMQResponse();
+        AMQResponseBody responseFrame = new AMQResponseBody();
         responseFrame.requestId = requestId;
         responseFrame.responseMark = responseMark;
         responseFrame.methodPayload = methodPayload;

Copied: incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponseBody.java (from r494058, incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponse.java)
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponseBody.java?view=diff&rev=494541&p1=incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponse.java&r1=494058&p2=incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponseBody.java&r2=494541
==============================================================================
--- incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponse.java (original)
+++ incubator/qpid/branches/qpid.0-9/java/common/src/main/java/org/apache/qpid/framing/AMQResponseBody.java Tue Jan  9 11:47:02 2007
@@ -22,36 +22,20 @@
 
 import org.apache.mina.common.ByteBuffer;
 
-public class AMQResponse extends AMQBody
+public class AMQResponseBody extends AMQRequestBody
 {
     public static final byte TYPE = (byte)AmqpConstants.frameResponseAsInt();
        
     // Fields declared in specification
-    public long requestId;
-    public long responseMark;
     public int batchOffset;
-    public AMQMethodBody methodPayload;
 
     // Constructor
-    public AMQResponse() {}
+    public AMQResponseBody() {}
 
     // Field methods
     
-    public long getRequestId() { return requestId; }
-    public long getResponseMark() { return responseMark; }
     public int  getBatchOffset() { return batchOffset; }
-    public AMQMethodBody getMethodPayload() { return methodPayload; }
-    
-    protected byte getFrameType()
-    {
-        return TYPE;
-    }
-    
-    protected int getSize()
-    {
-        return 8 + 8 + 4 + methodPayload.getBodySize();
-    }
-    
+        
     protected void writePayload(ByteBuffer buffer)
     {
         EncodingUtils.writeLong(buffer, requestId);
@@ -72,7 +56,7 @@
     public static AMQFrame createAMQFrame(int channelId, long requestId,
             long responseMark, int batchOffset, AMQMethodBody methodPayload)
     {
-        AMQResponse responseFrame = new AMQResponse();
+        AMQResponseBody responseFrame = new AMQResponseBody();
         responseFrame.requestId = requestId;
         responseFrame.responseMark = responseMark;
         responseFrame.batchOffset = batchOffset;